You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@accumulo.apache.org by ec...@apache.org on 2013/11/26 22:06:01 UTC

[01/10] git commit: ACCUMULO-1854 Remove compiler warnings

Updated Branches:
  refs/heads/master 2e4ce5e52 -> c3befc23d


ACCUMULO-1854 Remove compiler warnings


Project: http://git-wip-us.apache.org/repos/asf/accumulo/repo
Commit: http://git-wip-us.apache.org/repos/asf/accumulo/commit/f8e14c79
Tree: http://git-wip-us.apache.org/repos/asf/accumulo/tree/f8e14c79
Diff: http://git-wip-us.apache.org/repos/asf/accumulo/diff/f8e14c79

Branch: refs/heads/master
Commit: f8e14c794992bd5d8d530b50338b16436088c243
Parents: dd55dc7
Author: Christopher Tubbs <ct...@apache.org>
Authored: Tue Nov 26 13:16:17 2013 -0500
Committer: Christopher Tubbs <ct...@apache.org>
Committed: Tue Nov 26 13:16:17 2013 -0500

----------------------------------------------------------------------
 .../core/client/mapreduce/RangeInputSplit.java  | 81 ++++++++++----------
 .../mapreduce/AccumuloInputFormatTest.java      | 18 +++--
 .../accumulo/test/functional/ExamplesIT.java    | 27 ++++---
 3 files changed, 70 insertions(+), 56 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/f8e14c79/core/src/main/java/org/apache/accumulo/core/client/mapreduce/RangeInputSplit.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/RangeInputSplit.java b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/RangeInputSplit.java
index 59cc8d8..98b1a32 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/RangeInputSplit.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/RangeInputSplit.java
@@ -20,7 +20,6 @@ import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
 import java.math.BigInteger;
-import java.nio.charset.Charset;
 import java.util.ArrayList;
 import java.util.Collection;
 import java.util.HashSet;
@@ -132,6 +131,7 @@ public class RangeInputSplit extends InputSplit implements Writable {
   /**
    * This implementation of length is only an estimate, it does not provide exact values. Do not have your code rely on this return value.
    */
+  @Override
   public long getLength() throws IOException {
     Text startRow = range.isInfiniteStartKey() ? new Text(new byte[] {Byte.MIN_VALUE}) : range.getStartKey().getRow();
     Text stopRow = range.isInfiniteStopKey() ? new Text(new byte[] {Byte.MAX_VALUE}) : range.getEndKey().getRow();
@@ -151,10 +151,12 @@ public class RangeInputSplit extends InputSplit implements Writable {
     return diff + 1;
   }
 
+  @Override
   public String[] getLocations() throws IOException {
     return locations;
   }
 
+  @Override
   public void readFields(DataInput in) throws IOException {
     range.readFields(in);
     tableName = in.readUTF();
@@ -163,42 +165,42 @@ public class RangeInputSplit extends InputSplit implements Writable {
     locations = new String[numLocs];
     for (int i = 0; i < numLocs; ++i)
       locations[i] = in.readUTF();
-    
+
     if (in.readBoolean()) {
       isolatedScan = in.readBoolean();
     }
-    
+
     if (in.readBoolean()) {
       offline = in.readBoolean();
     }
-    
+
     if (in.readBoolean()) {
       localIterators = in.readBoolean();
     }
-    
+
     if (in.readBoolean()) {
       mockInstance = in.readBoolean();
     }
-    
+
     if (in.readBoolean()) {
       int numColumns = in.readInt();
       List<String> columns = new ArrayList<String>(numColumns);
       for (int i = 0; i < numColumns; i++) {
         columns.add(in.readUTF());
       }
-      
+
       fetchedColumns = InputConfigurator.deserializeFetchedColumns(columns);
     }
-    
+
     if (in.readBoolean()) {
       String strAuths = in.readUTF();
       auths = new Authorizations(strAuths.getBytes(Constants.UTF8));
     }
-    
+
     if (in.readBoolean()) {
       principal = in.readUTF();
     }
-    
+
     if (in.readBoolean()) {
       int ordinal = in.readInt();
       this.tokenSource = TokenSource.values()[ordinal];
@@ -208,32 +210,33 @@ public class RangeInputSplit extends InputSplit implements Writable {
           String tokenClass = in.readUTF();
           byte[] base64TokenBytes = in.readUTF().getBytes(Constants.UTF8);
           byte[] tokenBytes = Base64.decodeBase64(base64TokenBytes);
-          
+
           this.token = AuthenticationTokenSerializer.deserialize(tokenClass, tokenBytes);
           break;
-          
+
         case FILE:
           this.tokenFile = in.readUTF();
-          
+
           break;
         default:
-          throw new IOException("Cannot parse unknown TokenSource ordinal");      
+          throw new IOException("Cannot parse unknown TokenSource ordinal");
       }
     }
-    
+
     if (in.readBoolean()) {
       instanceName = in.readUTF();
     }
-    
+
     if (in.readBoolean()) {
       zooKeepers = in.readUTF();
     }
-    
+
     if (in.readBoolean()) {
       level = Level.toLevel(in.readInt());
     }
   }
 
+  @Override
   public void write(DataOutput out) throws IOException {
     range.write(out);
     out.writeUTF(tableName);
@@ -241,27 +244,27 @@ public class RangeInputSplit extends InputSplit implements Writable {
     out.writeInt(locations.length);
     for (int i = 0; i < locations.length; ++i)
       out.writeUTF(locations[i]);
-    
+
     out.writeBoolean(null != isolatedScan);
     if (null != isolatedScan) {
       out.writeBoolean(isolatedScan);
     }
-    
+
     out.writeBoolean(null != offline);
     if (null != offline) {
       out.writeBoolean(offline);
     }
-    
+
     out.writeBoolean(null != localIterators);
     if (null != localIterators) {
       out.writeBoolean(localIterators);
     }
-    
+
     out.writeBoolean(null != mockInstance);
     if (null != mockInstance) {
       out.writeBoolean(mockInstance);
     }
-    
+
     out.writeBoolean(null != fetchedColumns);
     if (null != fetchedColumns) {
       String[] cols = InputConfigurator.serializeColumns(fetchedColumns);
@@ -270,21 +273,21 @@ public class RangeInputSplit extends InputSplit implements Writable {
         out.writeUTF(col);
       }
     }
-    
+
     out.writeBoolean(null != auths);
     if (null != auths) {
       out.writeUTF(auths.serialize());
     }
-    
+
     out.writeBoolean(null != principal);
     if (null != principal) {
       out.writeUTF(principal);
     }
-    
+
     out.writeBoolean(null != tokenSource);
     if (null != tokenSource) {
       out.writeInt(tokenSource.ordinal());
-      
+
       if (null != token && null != tokenFile) {
         throw new IOException("Cannot use both inline AuthenticationToken and file-based AuthenticationToken");
       } else if (null != token) {
@@ -294,17 +297,17 @@ public class RangeInputSplit extends InputSplit implements Writable {
         out.writeUTF(tokenFile);
       }
     }
-    
+
     out.writeBoolean(null != instanceName);
     if (null != instanceName) {
       out.writeUTF(instanceName);
     }
-    
+
     out.writeBoolean(null != zooKeepers);
     if (null != zooKeepers) {
       out.writeUTF(zooKeepers);
     }
-    
+
     out.writeBoolean(null != level);
     if (null != level) {
       out.writeInt(level.toInt());
@@ -350,20 +353,20 @@ public class RangeInputSplit extends InputSplit implements Writable {
   public String getTableId() {
     return tableId;
   }
-  
+
   public Instance getInstance() {
     if (null == instanceName) {
       return null;
     }
-    
-    if (isMockInstance()) {  
+
+    if (isMockInstance()) {
       return new MockInstance(getInstanceName());
     }
-    
+
     if (null == zooKeepers) {
       return null;
     }
-    
+
     return new ZooKeeperInstance(ClientConfiguration.loadDefault().withInstance(getInstanceName()).withZkHosts(getZooKeepers()));
   }
 
@@ -390,16 +393,16 @@ public class RangeInputSplit extends InputSplit implements Writable {
   public void setPrincipal(String principal) {
     this.principal = principal;
   }
-  
+
   public AuthenticationToken getToken() {
     return token;
   }
-  
+
   public void setToken(AuthenticationToken token) {
     this.tokenSource = TokenSource.INLINE;
     this.token = token;
   }
-  
+
   public void setToken(String tokenFile) {
     this.tokenSource = TokenSource.FILE;
     this.tokenFile = tokenFile;
@@ -456,7 +459,7 @@ public class RangeInputSplit extends InputSplit implements Writable {
   public Set<Pair<Text,Text>> getFetchedColumns() {
     return fetchedColumns;
   }
-  
+
   public void setFetchedColumns(Collection<Pair<Text,Text>> fetchedColumns) {
     this.fetchedColumns = new HashSet<Pair<Text,Text>>();
     for (Pair<Text,Text> columns : fetchedColumns) {
@@ -479,7 +482,7 @@ public class RangeInputSplit extends InputSplit implements Writable {
   public Level getLogLevel() {
     return level;
   }
-  
+
   public void setLogLevel(Level level) {
     this.level = level;
   }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/f8e14c79/core/src/test/java/org/apache/accumulo/core/client/mapreduce/AccumuloInputFormatTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/client/mapreduce/AccumuloInputFormatTest.java b/core/src/test/java/org/apache/accumulo/core/client/mapreduce/AccumuloInputFormatTest.java
index 397b203..20b5f95 100644
--- a/core/src/test/java/org/apache/accumulo/core/client/mapreduce/AccumuloInputFormatTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/client/mapreduce/AccumuloInputFormatTest.java
@@ -302,6 +302,7 @@ public class AccumuloInputFormatTest {
 
   @Test
   public void testCorrectRangeInputSplits() throws Exception {
+    @SuppressWarnings("deprecation")
     Job job = new Job(new Configuration(), this.getClass().getSimpleName() + "_" + System.currentTimeMillis());
 
     String username = "user", table = "table", instance = "instance";
@@ -363,10 +364,13 @@ public class AccumuloInputFormatTest {
     }
     bw.close();
 
-    Assert.assertEquals(0, MRTester.main(new String[] {user, "", "testtable", "testPartialInputSplitDelegationToConfiguration",
-        EmptySplitsAccumuloInputFormat.class.getCanonicalName()}));
+    Assert.assertEquals(
+        0,
+        MRTester.main(new String[] {user, "", "testtable", "testPartialInputSplitDelegationToConfiguration",
+            EmptySplitsAccumuloInputFormat.class.getCanonicalName()}));
     assertNull(e1);
-    assertNull(e2);  }
+    assertNull(e2);
+  }
 
   @Test
   public void testPartialFailedInputSplitDelegationToConfiguration() throws Exception {
@@ -384,9 +388,11 @@ public class AccumuloInputFormatTest {
     }
     bw.close();
 
-    // We should fail before we even get into the Mapper because we can't make the RecordReader 
-    Assert.assertEquals(1, MRTester.main(new String[] {user, "", "testtable", "testPartialFailedInputSplitDelegationToConfiguration",
-        BadPasswordSplitsAccumuloInputFormat.class.getCanonicalName()}));
+    // We should fail before we even get into the Mapper because we can't make the RecordReader
+    Assert.assertEquals(
+        1,
+        MRTester.main(new String[] {user, "", "testtable", "testPartialFailedInputSplitDelegationToConfiguration",
+            BadPasswordSplitsAccumuloInputFormat.class.getCanonicalName()}));
     assertNull(e1);
     assertNull(e2);
   }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/f8e14c79/test/src/test/java/org/apache/accumulo/test/functional/ExamplesIT.java
----------------------------------------------------------------------
diff --git a/test/src/test/java/org/apache/accumulo/test/functional/ExamplesIT.java b/test/src/test/java/org/apache/accumulo/test/functional/ExamplesIT.java
index 84803f1..16b425f 100644
--- a/test/src/test/java/org/apache/accumulo/test/functional/ExamplesIT.java
+++ b/test/src/test/java/org/apache/accumulo/test/functional/ExamplesIT.java
@@ -74,7 +74,6 @@ import org.apache.accumulo.minicluster.MiniAccumuloCluster.LogWriter;
 import org.apache.accumulo.minicluster.MiniAccumuloConfig;
 import org.apache.accumulo.server.util.Admin;
 import org.apache.accumulo.test.TestIngest;
-import org.apache.accumulo.test.VerifyIngest;
 import org.apache.accumulo.tracer.TraceServer;
 import org.apache.hadoop.fs.FileSystem;
 import org.apache.hadoop.fs.Path;
@@ -173,14 +172,16 @@ public class ExamplesIT extends ConfigurableMacIT {
     // try the speed test a couple times in case the system is loaded with other tests
     for (int i = 0; i < 2; i++) {
       long now = System.currentTimeMillis();
-      assertEquals(0,  cluster.exec(RandomBatchScanner.class,"--seed", "7", "-i", instance, "-z",
-          keepers, "-u", user, "-p", ROOT_PASSWORD, "--num", "10000", "--min", "0", "--max", "1000000000", "--size", "50",
-          "--scanThreads", "4","-t", "bloom_test").waitFor());
+      assertEquals(
+          0,
+          cluster.exec(RandomBatchScanner.class, "--seed", "7", "-i", instance, "-z", keepers, "-u", user, "-p", ROOT_PASSWORD, "--num", "10000", "--min", "0",
+              "--max", "1000000000", "--size", "50", "--scanThreads", "4", "-t", "bloom_test").waitFor());
       diff = System.currentTimeMillis() - now;
       now = System.currentTimeMillis();
-      assertEquals(1,  cluster.exec(RandomBatchScanner.class,"--seed", "8", "-i", instance, "-z",
-          keepers, "-u", user, "-p", ROOT_PASSWORD, "--num", "10000", "--min", "0", "--max", "1000000000", "--size", "50",
-          "--scanThreads", "4","-t", "bloom_test").waitFor());
+      assertEquals(
+          1,
+          cluster.exec(RandomBatchScanner.class, "--seed", "8", "-i", instance, "-z", keepers, "-u", user, "-p", ROOT_PASSWORD, "--num", "10000", "--min", "0",
+              "--max", "1000000000", "--size", "50", "--scanThreads", "4", "-t", "bloom_test").waitFor());
       diff2 = System.currentTimeMillis() - now;
       if (diff2 < diff)
         break;
@@ -205,12 +206,13 @@ public class ExamplesIT extends ConfigurableMacIT {
     assertTrue(thisFile);
     // create a reverse index
     c.tableOperations().create("doc2Term");
-    assertEquals(0, cluster.exec(Reverse.class, "-i", instance, "-z", keepers, "--shardTable", "shard", "--doc2Term", "doc2Term", "-u", "root", "-p", passwd).waitFor());
+    assertEquals(0, cluster.exec(Reverse.class, "-i", instance, "-z", keepers, "--shardTable", "shard", "--doc2Term", "doc2Term", "-u", "root", "-p", passwd)
+        .waitFor());
     // run some queries
     assertEquals(
         0,
-        cluster.exec(ContinuousQuery.class, "-i", instance, "-z", keepers, "--shardTable", "shard", "--doc2Term", "doc2Term", "-u", "root", "-p", passwd, "--terms", "5", "--count",
-            "1000").waitFor());
+        cluster.exec(ContinuousQuery.class, "-i", instance, "-z", keepers, "--shardTable", "shard", "--doc2Term", "doc2Term", "-u", "root", "-p", passwd,
+            "--terms", "5", "--count", "1000").waitFor());
 
     log.info("Testing MaxMutation constraint");
     c.tableOperations().create("test_ingest");
@@ -227,7 +229,10 @@ public class ExamplesIT extends ConfigurableMacIT {
     log.info("Starting bulk ingest example");
     assertEquals(0, cluster.exec(GenerateTestData.class, "--start-row", "0", "--count", "10000", "--output", dir + "/tmp/input/data").waitFor());
     assertEquals(0, cluster.exec(SetupTable.class, "-i", instance, "-z", keepers, "-u", user, "-p", passwd, "--table", "bulkTable").waitFor());
-    assertEquals(0, cluster.exec(BulkIngestExample.class, "-i", instance, "-z", keepers, "-u", user, "-p", passwd, "--table", "bulkTable", "--inputDir", dir + "/tmp/input", "--workDir", dir + "/tmp").waitFor());
+    assertEquals(
+        0,
+        cluster.exec(BulkIngestExample.class, "-i", instance, "-z", keepers, "-u", user, "-p", passwd, "--table", "bulkTable", "--inputDir",
+            dir + "/tmp/input", "--workDir", dir + "/tmp").waitFor());
 
     log.info("Running TeraSortIngest example");
     exec(TeraSortIngest.class, new String[] {"--count", (1000 * 1000) + "", "-nk", "10", "-xk", "10", "-nv", "10", "-xv", "10", "-t", "sorted", "-i", instance,


[04/10] git commit: Merge branch '1.4.5-SNAPSHOT' into 1.5.1-SNAPSHOT

Posted by ec...@apache.org.
Merge branch '1.4.5-SNAPSHOT' into 1.5.1-SNAPSHOT


Project: http://git-wip-us.apache.org/repos/asf/accumulo/repo
Commit: http://git-wip-us.apache.org/repos/asf/accumulo/commit/a550169d
Tree: http://git-wip-us.apache.org/repos/asf/accumulo/tree/a550169d
Diff: http://git-wip-us.apache.org/repos/asf/accumulo/diff/a550169d

Branch: refs/heads/master
Commit: a550169d14c82834aa51b5511e94d8bb3b6c3464
Parents: 11ba435 394b2b2
Author: Eric Newton <er...@gmail.com>
Authored: Tue Nov 26 15:05:39 2013 -0500
Committer: Eric Newton <er...@gmail.com>
Committed: Tue Nov 26 15:05:39 2013 -0500

----------------------------------------------------------------------

----------------------------------------------------------------------



[03/10] git commit: ACCUMULO-1793 make the default hadoop-2.2.0

Posted by ec...@apache.org.
ACCUMULO-1793 make the default hadoop-2.2.0


Project: http://git-wip-us.apache.org/repos/asf/accumulo/repo
Commit: http://git-wip-us.apache.org/repos/asf/accumulo/commit/394b2b29
Tree: http://git-wip-us.apache.org/repos/asf/accumulo/tree/394b2b29
Diff: http://git-wip-us.apache.org/repos/asf/accumulo/diff/394b2b29

Branch: refs/heads/master
Commit: 394b2b29b5b04fcc8c7d94aa5023ad376fe61114
Parents: e41581e
Author: Eric Newton <er...@gmail.com>
Authored: Tue Nov 26 15:04:54 2013 -0500
Committer: Eric Newton <er...@gmail.com>
Committed: Tue Nov 26 15:04:54 2013 -0500

----------------------------------------------------------------------
 README  | 4 ++--
 pom.xml | 6 +++---
 2 files changed, 5 insertions(+), 5 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/394b2b29/README
----------------------------------------------------------------------
diff --git a/README b/README
index f01048b..878bbe3 100644
--- a/README
+++ b/README
@@ -22,8 +22,8 @@ Accumulo compiles against Hadoop 0.20.203.0.  To compile against a different ver
 that is compatible with Hadoop 1.0, specify hadoop.version on the command line,
 e.g. "-Dhadoop.version=0.20.205.0" or "-Dhadoop.version=1.1.0".  To compile 
 against Hadoop 2.0, specify "-Dhadoop.profile=2.0".  By default this uses
-2.0.2-alpha.  To compile against a different 2.0-compatible version, specify
-the profile and version, e.g. "-Dhadoop.profile=2.0 -Dhadoop.version=2.2.0".
+2.2.0.  To compile against a different 2.0-compatible version, specify
+the profile and version, e.g. "-Dhadoop.profile=2.0 -Dhadoop.version=0.23.5".
 
 If you are running on another Unix-like operating system (OSX, etc) then
 you may wish to build the native libraries.  They are not strictly necessary

http://git-wip-us.apache.org/repos/asf/accumulo/blob/394b2b29/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index 9856ae9..a8d0500 100644
--- a/pom.xml
+++ b/pom.xml
@@ -675,9 +675,9 @@
         </property>
       </activation>
       <properties>
-        <slf4j.version>1.6.1</slf4j.version>
-        <hadoop.version>2.0.2-alpha</hadoop.version>
-        <avro.version>1.5.3</avro.version>
+        <slf4j.version>1.7.5</slf4j.version>
+        <hadoop.version>2.2.0</hadoop.version>
+        <avro.version>1.7.4</avro.version>
       </properties>
       <dependencyManagement>
         <dependencies>


[07/10] git commit: ACCUMULO-1934 cleaning up imports, dead code, unused vars

Posted by ec...@apache.org.
ACCUMULO-1934 cleaning up imports, dead code, unused vars


Project: http://git-wip-us.apache.org/repos/asf/accumulo/repo
Commit: http://git-wip-us.apache.org/repos/asf/accumulo/commit/8d39b09b
Tree: http://git-wip-us.apache.org/repos/asf/accumulo/tree/8d39b09b
Diff: http://git-wip-us.apache.org/repos/asf/accumulo/diff/8d39b09b

Branch: refs/heads/master
Commit: 8d39b09b212a67ad0e8379ddf18cf3624d9d2152
Parents: 394b2b2
Author: Eric Newton <er...@gmail.com>
Authored: Tue Nov 26 15:52:44 2013 -0500
Committer: Eric Newton <er...@gmail.com>
Committed: Tue Nov 26 15:52:44 2013 -0500

----------------------------------------------------------------------
 .../core/client/mapreduce/InputFormatBase.java  |  5 ---
 .../core/client/IteratorSettingTest.java        |  4 +-
 .../user/IntersectingIteratorTest.java          |  2 +-
 .../core/util/LocalityGroupUtilTest.java        |  2 +-
 .../org/apache/accumulo/proxy/SimpleTest.java   |  6 +--
 .../accumulo/proxy/TestProxyReadWrite.java      | 10 -----
 .../monitor/servlets/GcStatusServlet.java       |  1 -
 .../accumulo/server/tabletserver/Tablet.java    |  2 -
 .../accumulo/server/util/MetadataTable.java     | 43 --------------------
 .../server/client/BulkImporterTest.java         |  3 +-
 .../accumulo/server/gc/TestConfirmDeletes.java  |  3 +-
 .../iterators/MetadataBulkLoadFilterTest.java   |  2 +-
 .../balancer/DefaultLoadBalancerTest.java       |  3 +-
 .../master/balancer/TableLoadBalancerTest.java  |  3 +-
 .../zookeeper/DistributedReadWriteLockTest.java |  2 +-
 .../zookeeper/TransactionWatcherTest.java       |  2 +-
 .../cloudtrace/instrument/CountSamplerTest.java |  2 +-
 17 files changed, 13 insertions(+), 82 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/8d39b09b/src/core/src/main/java/org/apache/accumulo/core/client/mapreduce/InputFormatBase.java
----------------------------------------------------------------------
diff --git a/src/core/src/main/java/org/apache/accumulo/core/client/mapreduce/InputFormatBase.java b/src/core/src/main/java/org/apache/accumulo/core/client/mapreduce/InputFormatBase.java
index bd90b8c..8fe0347 100644
--- a/src/core/src/main/java/org/apache/accumulo/core/client/mapreduce/InputFormatBase.java
+++ b/src/core/src/main/java/org/apache/accumulo/core/client/mapreduce/InputFormatBase.java
@@ -18,14 +18,11 @@ package org.apache.accumulo.core.client.mapreduce;
 
 import java.io.ByteArrayInputStream;
 import java.io.ByteArrayOutputStream;
-import java.io.DataInput;
 import java.io.DataInputStream;
-import java.io.DataOutput;
 import java.io.DataOutputStream;
 import java.io.IOException;
 import java.io.UnsupportedEncodingException;
 import java.lang.reflect.InvocationTargetException;
-import java.math.BigInteger;
 import java.net.InetAddress;
 import java.net.URLDecoder;
 import java.net.URLEncoder;
@@ -61,7 +58,6 @@ import org.apache.accumulo.core.client.impl.Tables;
 import org.apache.accumulo.core.client.impl.TabletLocator;
 import org.apache.accumulo.core.client.mock.MockInstance;
 import org.apache.accumulo.core.client.mock.MockTabletLocator;
-import org.apache.accumulo.core.data.ByteSequence;
 import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.data.KeyExtent;
 import org.apache.accumulo.core.data.PartialKey;
@@ -82,7 +78,6 @@ import org.apache.accumulo.core.util.UtilWaitThread;
 import org.apache.commons.codec.binary.Base64;
 import org.apache.hadoop.conf.Configuration;
 import org.apache.hadoop.io.Text;
-import org.apache.hadoop.io.Writable;
 import org.apache.hadoop.mapreduce.InputFormat;
 import org.apache.hadoop.mapreduce.InputSplit;
 import org.apache.hadoop.mapreduce.JobContext;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/8d39b09b/src/core/src/test/java/org/apache/accumulo/core/client/IteratorSettingTest.java
----------------------------------------------------------------------
diff --git a/src/core/src/test/java/org/apache/accumulo/core/client/IteratorSettingTest.java b/src/core/src/test/java/org/apache/accumulo/core/client/IteratorSettingTest.java
index 69bf1b5..ccb3cd6 100644
--- a/src/core/src/test/java/org/apache/accumulo/core/client/IteratorSettingTest.java
+++ b/src/core/src/test/java/org/apache/accumulo/core/client/IteratorSettingTest.java
@@ -1,10 +1,10 @@
 package org.apache.accumulo.core.client;
 
-import static org.junit.Assert.*;
+import static org.junit.Assert.assertEquals;
+import static org.junit.Assert.assertNotEquals;
 
 import org.apache.accumulo.core.iterators.Combiner;
 import org.apache.accumulo.core.iterators.DevNull;
-import org.apache.hadoop.io.Writable;
 import org.junit.Test;
 
 /**

http://git-wip-us.apache.org/repos/asf/accumulo/blob/8d39b09b/src/core/src/test/java/org/apache/accumulo/core/iterators/user/IntersectingIteratorTest.java
----------------------------------------------------------------------
diff --git a/src/core/src/test/java/org/apache/accumulo/core/iterators/user/IntersectingIteratorTest.java b/src/core/src/test/java/org/apache/accumulo/core/iterators/user/IntersectingIteratorTest.java
index df34b3c..a6b94d5 100644
--- a/src/core/src/test/java/org/apache/accumulo/core/iterators/user/IntersectingIteratorTest.java
+++ b/src/core/src/test/java/org/apache/accumulo/core/iterators/user/IntersectingIteratorTest.java
@@ -26,7 +26,7 @@ import java.util.Map.Entry;
 import java.util.Random;
 import java.util.TreeMap;
 
-import junit.framework.Assert;
+import org.junit.Assert;
 import junit.framework.TestCase;
 
 import org.apache.accumulo.core.Constants;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/8d39b09b/src/core/src/test/java/org/apache/accumulo/core/util/LocalityGroupUtilTest.java
----------------------------------------------------------------------
diff --git a/src/core/src/test/java/org/apache/accumulo/core/util/LocalityGroupUtilTest.java b/src/core/src/test/java/org/apache/accumulo/core/util/LocalityGroupUtilTest.java
index a1eb9e8..526e57a 100644
--- a/src/core/src/test/java/org/apache/accumulo/core/util/LocalityGroupUtilTest.java
+++ b/src/core/src/test/java/org/apache/accumulo/core/util/LocalityGroupUtilTest.java
@@ -20,7 +20,7 @@ import java.util.HashSet;
 import java.util.Map;
 import java.util.Set;
 
-import junit.framework.Assert;
+import org.junit.Assert;
 
 import org.apache.accumulo.core.conf.ConfigurationCopy;
 import org.apache.accumulo.core.data.ArrayByteSequence;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/8d39b09b/src/proxy/src/test/java/org/apache/accumulo/proxy/SimpleTest.java
----------------------------------------------------------------------
diff --git a/src/proxy/src/test/java/org/apache/accumulo/proxy/SimpleTest.java b/src/proxy/src/test/java/org/apache/accumulo/proxy/SimpleTest.java
index f6533c2..d3b45ae 100644
--- a/src/proxy/src/test/java/org/apache/accumulo/proxy/SimpleTest.java
+++ b/src/proxy/src/test/java/org/apache/accumulo/proxy/SimpleTest.java
@@ -411,11 +411,7 @@ public class SimpleTest {
 
   @Test(timeout = 10000)
   public void testInstanceOperations() throws Exception {
-    int tservers = 0;
-    for (String tserver : client.getTabletServers(creds)) {
-      tservers++;
-    }
-    assertTrue(tservers > 0);
+    assertTrue(client.getTabletServers(creds).size() > 0);
     
     // get something we know is in the site config
     Map<String,String> cfg = client.getSiteConfiguration(creds);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/8d39b09b/src/proxy/src/test/java/org/apache/accumulo/proxy/TestProxyReadWrite.java
----------------------------------------------------------------------
diff --git a/src/proxy/src/test/java/org/apache/accumulo/proxy/TestProxyReadWrite.java b/src/proxy/src/test/java/org/apache/accumulo/proxy/TestProxyReadWrite.java
index cb4d364..97c2384 100644
--- a/src/proxy/src/test/java/org/apache/accumulo/proxy/TestProxyReadWrite.java
+++ b/src/proxy/src/test/java/org/apache/accumulo/proxy/TestProxyReadWrite.java
@@ -29,14 +29,12 @@ import java.util.Properties;
 import java.util.Set;
 import java.util.TreeMap;
 
-import org.apache.accumulo.core.data.Mutation;
 import org.apache.accumulo.core.iterators.user.RegExFilter;
 import org.apache.accumulo.proxy.thrift.BatchScanOptions;
 import org.apache.accumulo.proxy.thrift.ColumnUpdate;
 import org.apache.accumulo.proxy.thrift.IteratorSetting;
 import org.apache.accumulo.proxy.thrift.Key;
 import org.apache.accumulo.proxy.thrift.KeyValue;
-import org.apache.accumulo.proxy.thrift.MutationsRejectedException;
 import org.apache.accumulo.proxy.thrift.Range;
 import org.apache.accumulo.proxy.thrift.ScanColumn;
 import org.apache.accumulo.proxy.thrift.ScanOptions;
@@ -148,14 +146,6 @@ public class TestProxyReadWrite {
     assertEquals(i, 50000);
   }
 
-    private class MyTest {
-
-        public void addMutation(Mutation m) throws MutationsRejectedException {
-            throw new MutationsRejectedException();
-        }
-    }
-
-
   /**
    * Insert 100000 cells which have as the row [0..99999] (padded with zeros). Set a columnFamily so only the entries with specified column family come back (there should be
    * 50,000)

http://git-wip-us.apache.org/repos/asf/accumulo/blob/8d39b09b/src/server/src/main/java/org/apache/accumulo/server/monitor/servlets/GcStatusServlet.java
----------------------------------------------------------------------
diff --git a/src/server/src/main/java/org/apache/accumulo/server/monitor/servlets/GcStatusServlet.java b/src/server/src/main/java/org/apache/accumulo/server/monitor/servlets/GcStatusServlet.java
index 3c2626e..b7795fb 100644
--- a/src/server/src/main/java/org/apache/accumulo/server/monitor/servlets/GcStatusServlet.java
+++ b/src/server/src/main/java/org/apache/accumulo/server/monitor/servlets/GcStatusServlet.java
@@ -16,7 +16,6 @@
  */
 package org.apache.accumulo.server.monitor.servlets;
 
-import java.text.DateFormat;
 import java.text.SimpleDateFormat;
 
 import javax.servlet.http.HttpServletRequest;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/8d39b09b/src/server/src/main/java/org/apache/accumulo/server/tabletserver/Tablet.java
----------------------------------------------------------------------
diff --git a/src/server/src/main/java/org/apache/accumulo/server/tabletserver/Tablet.java b/src/server/src/main/java/org/apache/accumulo/server/tabletserver/Tablet.java
index 09903bf..f2d9b1d 100644
--- a/src/server/src/main/java/org/apache/accumulo/server/tabletserver/Tablet.java
+++ b/src/server/src/main/java/org/apache/accumulo/server/tabletserver/Tablet.java
@@ -23,8 +23,6 @@ package org.apache.accumulo.server.tabletserver;
  * 
  */
 
-import java.io.ByteArrayInputStream;
-import java.io.DataInputStream;
 import java.io.FileNotFoundException;
 import java.io.IOException;
 import java.util.ArrayList;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/8d39b09b/src/server/src/main/java/org/apache/accumulo/server/util/MetadataTable.java
----------------------------------------------------------------------
diff --git a/src/server/src/main/java/org/apache/accumulo/server/util/MetadataTable.java b/src/server/src/main/java/org/apache/accumulo/server/util/MetadataTable.java
index a9b72e0..df3e7c1 100644
--- a/src/server/src/main/java/org/apache/accumulo/server/util/MetadataTable.java
+++ b/src/server/src/main/java/org/apache/accumulo/server/util/MetadataTable.java
@@ -35,7 +35,6 @@ import java.util.Set;
 import java.util.SortedMap;
 import java.util.SortedSet;
 import java.util.TreeMap;
-import java.util.TreeSet;
 
 import org.apache.accumulo.core.Constants;
 import org.apache.accumulo.core.client.AccumuloException;
@@ -66,7 +65,6 @@ import org.apache.accumulo.core.util.CachedConfiguration;
 import org.apache.accumulo.core.util.ColumnFQ;
 import org.apache.accumulo.core.util.Pair;
 import org.apache.accumulo.core.util.StringUtil;
-import org.apache.accumulo.core.util.TextUtil;
 import org.apache.accumulo.core.util.UtilWaitThread;
 import org.apache.accumulo.core.zookeeper.ZooUtil;
 import org.apache.accumulo.core.zookeeper.ZooUtil.NodeExistsPolicy;
@@ -337,47 +335,6 @@ public class MetadataTable extends org.apache.accumulo.core.util.MetadataTable {
     
   }
   
-  /**
-   * convenience method for reading a metadata tablet's data file entries from the root tablet
-   * 
-   */
-  private static SortedMap<Key,Value> getRootMetadataDataFileEntries(KeyExtent extent, AuthInfo credentials) {
-    SortedSet<Column> columns = new TreeSet<Column>();
-    columns.add(new Column(TextUtil.getBytes(Constants.METADATA_DATAFILE_COLUMN_FAMILY), null, null));
-    return getRootMetadataDataEntries(extent, columns, credentials);
-  }
-  
-  private static SortedMap<Key,Value> getRootMetadataDataEntries(KeyExtent extent, SortedSet<Column> columns, AuthInfo credentials) {
-    
-    try {
-      SortedMap<Key,Value> entries = new TreeMap<Key,Value>();
-      
-      Text metadataEntry = extent.getMetadataEntry();
-      Text startRow;
-      boolean more = getBatchFromRootTablet(credentials, metadataEntry, entries, columns, false, Constants.SCAN_BATCH_SIZE);
-      
-      while (more) {
-        startRow = entries.lastKey().getRow(); // set end row
-        more = getBatchFromRootTablet(credentials, startRow, entries, columns, false, Constants.SCAN_BATCH_SIZE);
-      }
-      
-      Iterator<Key> iter = entries.keySet().iterator();
-      while (iter.hasNext()) {
-        Key key = iter.next();
-        if (key.compareRow(metadataEntry) != 0) {
-          iter.remove();
-        }
-      }
-      
-      return entries;
-      
-    } catch (AccumuloSecurityException e) {
-      log.warn("Unauthorized access...");
-      return new TreeMap<Key,Value>();
-    }
-    
-  }
-  
   public static boolean recordRootTabletLocation(String address) {
     IZooReaderWriter zoo = ZooReaderWriter.getInstance();
     for (int i = 0; i < SAVE_ROOT_TABLET_RETRIES; i++) {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/8d39b09b/src/server/src/test/java/org/apache/accumulo/server/client/BulkImporterTest.java
----------------------------------------------------------------------
diff --git a/src/server/src/test/java/org/apache/accumulo/server/client/BulkImporterTest.java b/src/server/src/test/java/org/apache/accumulo/server/client/BulkImporterTest.java
index 9e9e80f..d5f8739 100644
--- a/src/server/src/test/java/org/apache/accumulo/server/client/BulkImporterTest.java
+++ b/src/server/src/test/java/org/apache/accumulo/server/client/BulkImporterTest.java
@@ -23,8 +23,6 @@ import java.util.Map;
 import java.util.SortedSet;
 import java.util.TreeSet;
 
-import junit.framework.Assert;
-
 import org.apache.accumulo.core.client.AccumuloException;
 import org.apache.accumulo.core.client.AccumuloSecurityException;
 import org.apache.accumulo.core.client.TableNotFoundException;
@@ -43,6 +41,7 @@ import org.apache.commons.lang.NotImplementedException;
 import org.apache.hadoop.fs.FileSystem;
 import org.apache.hadoop.fs.Path;
 import org.apache.hadoop.io.Text;
+import org.junit.Assert;
 import org.junit.Test;
 
 public class BulkImporterTest {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/8d39b09b/src/server/src/test/java/org/apache/accumulo/server/gc/TestConfirmDeletes.java
----------------------------------------------------------------------
diff --git a/src/server/src/test/java/org/apache/accumulo/server/gc/TestConfirmDeletes.java b/src/server/src/test/java/org/apache/accumulo/server/gc/TestConfirmDeletes.java
index f3e992e..be444dd 100644
--- a/src/server/src/test/java/org/apache/accumulo/server/gc/TestConfirmDeletes.java
+++ b/src/server/src/test/java/org/apache/accumulo/server/gc/TestConfirmDeletes.java
@@ -22,8 +22,6 @@ import java.util.Map.Entry;
 import java.util.SortedSet;
 import java.util.TreeSet;
 
-import junit.framework.Assert;
-
 import org.apache.accumulo.core.Constants;
 import org.apache.accumulo.core.client.BatchWriter;
 import org.apache.accumulo.core.client.Connector;
@@ -39,6 +37,7 @@ import org.apache.accumulo.core.security.thrift.AuthInfo;
 import org.apache.accumulo.core.util.CachedConfiguration;
 import org.apache.hadoop.fs.FileSystem;
 import org.apache.hadoop.io.Text;
+import org.junit.Assert;
 import org.junit.Test;
 
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/8d39b09b/src/server/src/test/java/org/apache/accumulo/server/iterators/MetadataBulkLoadFilterTest.java
----------------------------------------------------------------------
diff --git a/src/server/src/test/java/org/apache/accumulo/server/iterators/MetadataBulkLoadFilterTest.java b/src/server/src/test/java/org/apache/accumulo/server/iterators/MetadataBulkLoadFilterTest.java
index 6233828..2ce25cc 100644
--- a/src/server/src/test/java/org/apache/accumulo/server/iterators/MetadataBulkLoadFilterTest.java
+++ b/src/server/src/test/java/org/apache/accumulo/server/iterators/MetadataBulkLoadFilterTest.java
@@ -21,7 +21,7 @@ import java.util.ArrayList;
 import java.util.HashMap;
 import java.util.TreeMap;
 
-import junit.framework.Assert;
+import org.junit.Assert;
 
 import org.apache.accumulo.core.Constants;
 import org.apache.accumulo.core.conf.AccumuloConfiguration;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/8d39b09b/src/server/src/test/java/org/apache/accumulo/server/master/balancer/DefaultLoadBalancerTest.java
----------------------------------------------------------------------
diff --git a/src/server/src/test/java/org/apache/accumulo/server/master/balancer/DefaultLoadBalancerTest.java b/src/server/src/test/java/org/apache/accumulo/server/master/balancer/DefaultLoadBalancerTest.java
index 7e715af..2c55f5d 100644
--- a/src/server/src/test/java/org/apache/accumulo/server/master/balancer/DefaultLoadBalancerTest.java
+++ b/src/server/src/test/java/org/apache/accumulo/server/master/balancer/DefaultLoadBalancerTest.java
@@ -32,8 +32,6 @@ import java.util.SortedMap;
 import java.util.TreeMap;
 import java.util.Map.Entry;
 
-import junit.framework.Assert;
-
 import org.apache.accumulo.core.data.KeyExtent;
 import org.apache.accumulo.core.master.thrift.TableInfo;
 import org.apache.accumulo.core.master.thrift.TabletServerStatus;
@@ -45,6 +43,7 @@ import org.apache.accumulo.server.master.state.TServerInstance;
 import org.apache.accumulo.server.master.state.TabletMigration;
 import org.apache.hadoop.io.Text;
 import org.apache.thrift.TException;
+import org.junit.Assert;
 import org.junit.Test;
 
 public class DefaultLoadBalancerTest {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/8d39b09b/src/server/src/test/java/org/apache/accumulo/server/master/balancer/TableLoadBalancerTest.java
----------------------------------------------------------------------
diff --git a/src/server/src/test/java/org/apache/accumulo/server/master/balancer/TableLoadBalancerTest.java b/src/server/src/test/java/org/apache/accumulo/server/master/balancer/TableLoadBalancerTest.java
index 684c851..662b66d 100644
--- a/src/server/src/test/java/org/apache/accumulo/server/master/balancer/TableLoadBalancerTest.java
+++ b/src/server/src/test/java/org/apache/accumulo/server/master/balancer/TableLoadBalancerTest.java
@@ -25,8 +25,6 @@ import java.util.Set;
 import java.util.SortedMap;
 import java.util.TreeMap;
 
-import junit.framework.Assert;
-
 import org.apache.accumulo.core.client.Connector;
 import org.apache.accumulo.core.client.admin.TableOperations;
 import org.apache.accumulo.core.client.mock.MockInstance;
@@ -40,6 +38,7 @@ import org.apache.accumulo.server.master.state.TServerInstance;
 import org.apache.accumulo.server.master.state.TabletMigration;
 import org.apache.hadoop.io.Text;
 import org.apache.thrift.TException;
+import org.junit.Assert;
 import org.junit.Test;
 
 public class TableLoadBalancerTest {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/8d39b09b/src/server/src/test/java/org/apache/accumulo/server/zookeeper/DistributedReadWriteLockTest.java
----------------------------------------------------------------------
diff --git a/src/server/src/test/java/org/apache/accumulo/server/zookeeper/DistributedReadWriteLockTest.java b/src/server/src/test/java/org/apache/accumulo/server/zookeeper/DistributedReadWriteLockTest.java
index b77a3ea..3964090 100644
--- a/src/server/src/test/java/org/apache/accumulo/server/zookeeper/DistributedReadWriteLockTest.java
+++ b/src/server/src/test/java/org/apache/accumulo/server/zookeeper/DistributedReadWriteLockTest.java
@@ -21,7 +21,7 @@ import java.util.TreeMap;
 import java.util.concurrent.locks.Lock;
 import java.util.concurrent.locks.ReadWriteLock;
 
-import junit.framework.Assert;
+import org.junit.Assert;
 
 import org.apache.accumulo.server.zookeeper.DistributedReadWriteLock;
 import org.apache.accumulo.server.zookeeper.DistributedReadWriteLock.QueueLock;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/8d39b09b/src/server/src/test/java/org/apache/accumulo/server/zookeeper/TransactionWatcherTest.java
----------------------------------------------------------------------
diff --git a/src/server/src/test/java/org/apache/accumulo/server/zookeeper/TransactionWatcherTest.java b/src/server/src/test/java/org/apache/accumulo/server/zookeeper/TransactionWatcherTest.java
index ced70ea..f45e780 100644
--- a/src/server/src/test/java/org/apache/accumulo/server/zookeeper/TransactionWatcherTest.java
+++ b/src/server/src/test/java/org/apache/accumulo/server/zookeeper/TransactionWatcherTest.java
@@ -22,7 +22,7 @@ import java.util.List;
 import java.util.Map;
 import java.util.concurrent.Callable;
 
-import junit.framework.Assert;
+import org.junit.Assert;
 
 import org.apache.accumulo.server.zookeeper.TransactionWatcher;
 import org.junit.Test;

http://git-wip-us.apache.org/repos/asf/accumulo/blob/8d39b09b/src/trace/src/test/java/org/apache/accumulo/cloudtrace/instrument/CountSamplerTest.java
----------------------------------------------------------------------
diff --git a/src/trace/src/test/java/org/apache/accumulo/cloudtrace/instrument/CountSamplerTest.java b/src/trace/src/test/java/org/apache/accumulo/cloudtrace/instrument/CountSamplerTest.java
index df7a831..baf1618 100644
--- a/src/trace/src/test/java/org/apache/accumulo/cloudtrace/instrument/CountSamplerTest.java
+++ b/src/trace/src/test/java/org/apache/accumulo/cloudtrace/instrument/CountSamplerTest.java
@@ -16,9 +16,9 @@
  */
 package org.apache.accumulo.cloudtrace.instrument;
 
-import junit.framework.Assert;
 
 import org.apache.accumulo.cloudtrace.instrument.CountSampler;
+import org.junit.Assert;
 import org.junit.Test;
 
 public class CountSamplerTest {


[09/10] git commit: Merge branch '1.5.1-SNAPSHOT' into 1.6.0-SNAPSHOT

Posted by ec...@apache.org.
Merge branch '1.5.1-SNAPSHOT' into 1.6.0-SNAPSHOT


Project: http://git-wip-us.apache.org/repos/asf/accumulo/repo
Commit: http://git-wip-us.apache.org/repos/asf/accumulo/commit/3711f41c
Tree: http://git-wip-us.apache.org/repos/asf/accumulo/tree/3711f41c
Diff: http://git-wip-us.apache.org/repos/asf/accumulo/diff/3711f41c

Branch: refs/heads/master
Commit: 3711f41cffb3cd815d652a0100ab1420e9a2c66b
Parents: 54f737f 374f46f
Author: Eric Newton <er...@gmail.com>
Authored: Tue Nov 26 16:05:56 2013 -0500
Committer: Eric Newton <er...@gmail.com>
Committed: Tue Nov 26 16:05:56 2013 -0500

----------------------------------------------------------------------

----------------------------------------------------------------------



[06/10] git commit: Merge branch '1.6.0-SNAPSHOT' of https://git-wip-us.apache.org/repos/asf/accumulo into 1.6.0-SNAPSHOT

Posted by ec...@apache.org.
Merge branch '1.6.0-SNAPSHOT' of https://git-wip-us.apache.org/repos/asf/accumulo into 1.6.0-SNAPSHOT


Project: http://git-wip-us.apache.org/repos/asf/accumulo/repo
Commit: http://git-wip-us.apache.org/repos/asf/accumulo/commit/54f737f2
Tree: http://git-wip-us.apache.org/repos/asf/accumulo/tree/54f737f2
Diff: http://git-wip-us.apache.org/repos/asf/accumulo/diff/54f737f2

Branch: refs/heads/master
Commit: 54f737f2e6259fa424be9d3aa4245956ebea30cd
Parents: f460013 f8e14c7
Author: Eric Newton <er...@gmail.com>
Authored: Tue Nov 26 15:08:40 2013 -0500
Committer: Eric Newton <er...@gmail.com>
Committed: Tue Nov 26 15:08:40 2013 -0500

----------------------------------------------------------------------
 .../core/client/mapreduce/RangeInputSplit.java  | 81 ++++++++++----------
 .../mapreduce/AccumuloInputFormatTest.java      | 18 +++--
 .../accumulo/test/functional/ExamplesIT.java    | 27 ++++---
 3 files changed, 70 insertions(+), 56 deletions(-)
----------------------------------------------------------------------



[02/10] git commit: ACCUMULO-1795 Default Hadoop 1.0 to 0.20.203.0.

Posted by ec...@apache.org.
ACCUMULO-1795 Default Hadoop 1.0 to 0.20.203.0.

Signed-off-by: Eric Newton <er...@gmail.com>


Project: http://git-wip-us.apache.org/repos/asf/accumulo/repo
Commit: http://git-wip-us.apache.org/repos/asf/accumulo/commit/e41581ea
Tree: http://git-wip-us.apache.org/repos/asf/accumulo/tree/e41581ea
Diff: http://git-wip-us.apache.org/repos/asf/accumulo/diff/e41581ea

Branch: refs/heads/master
Commit: e41581eac8e01cb430706c4ac838127cb61d9176
Parents: 51dd805
Author: Bill Havanki <bh...@cloudera.com>
Authored: Thu Nov 21 16:16:08 2013 -0500
Committer: Eric Newton <er...@gmail.com>
Committed: Tue Nov 26 14:54:40 2013 -0500

----------------------------------------------------------------------
 README  | 7 ++++---
 pom.xml | 2 +-
 2 files changed, 5 insertions(+), 4 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/e41581ea/README
----------------------------------------------------------------------
diff --git a/README b/README
index 674769d..f01048b 100644
--- a/README
+++ b/README
@@ -18,12 +18,12 @@ have maven configured to get Accumulo prerequisites from repositories.  See
 the pom.xml file for the necessary components.
 
 Run "mvn package && mvn assembly:single -N". By default,
-Accumulo compiles against Hadoop 1.0.4.  To compile against a different version
+Accumulo compiles against Hadoop 0.20.203.0.  To compile against a different version
 that is compatible with Hadoop 1.0, specify hadoop.version on the command line,
 e.g. "-Dhadoop.version=0.20.205.0" or "-Dhadoop.version=1.1.0".  To compile 
 against Hadoop 2.0, specify "-Dhadoop.profile=2.0".  By default this uses
 2.0.2-alpha.  To compile against a different 2.0-compatible version, specify
-the profile and version, e.g. "-Dhadoop.profile=2.0 -Dhadoop.version=0.23.5".
+the profile and version, e.g. "-Dhadoop.profile=2.0 -Dhadoop.version=2.2.0".
 
 If you are running on another Unix-like operating system (OSX, etc) then
 you may wish to build the native libraries.  They are not strictly necessary
@@ -70,7 +70,8 @@ found in the same location on every machine in the cluster.  You will need to
 have password-less ssh set up as described in the hadoop documentation. 
 
 You will need to have hadoop installed and configured on your system.
-Accumulo 1.4.5-SNAPSHOT has been tested with hadoop version 0.20.2.
+Accumulo 1.4.5-SNAPSHOT has been tested with hadoop version 0.20.2 and
+0.20.203.0.
 
 The example accumulo configuration files are placed in directories based on the 
 memory footprint for the accumulo processes.  If you are using native libraries

http://git-wip-us.apache.org/repos/asf/accumulo/blob/e41581ea/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index d664a5b..9856ae9 100644
--- a/pom.xml
+++ b/pom.xml
@@ -650,7 +650,7 @@
         </property>
       </activation>
       <properties>
-        <hadoop.version>1.0.4</hadoop.version>
+        <hadoop.version>0.20.203.0</hadoop.version>
         <slf4j.version>1.4.3</slf4j.version>
       </properties>
       <dependencyManagement>


[10/10] git commit: Merge branch '1.6.0-SNAPSHOT'

Posted by ec...@apache.org.
Merge branch '1.6.0-SNAPSHOT'


Project: http://git-wip-us.apache.org/repos/asf/accumulo/repo
Commit: http://git-wip-us.apache.org/repos/asf/accumulo/commit/c3befc23
Tree: http://git-wip-us.apache.org/repos/asf/accumulo/tree/c3befc23
Diff: http://git-wip-us.apache.org/repos/asf/accumulo/diff/c3befc23

Branch: refs/heads/master
Commit: c3befc23db249e784bb533ad26294ecd58f19ea2
Parents: 2e4ce5e 3711f41
Author: Eric Newton <er...@gmail.com>
Authored: Tue Nov 26 16:06:09 2013 -0500
Committer: Eric Newton <er...@gmail.com>
Committed: Tue Nov 26 16:06:09 2013 -0500

----------------------------------------------------------------------
 .../core/client/mapreduce/RangeInputSplit.java  | 81 ++++++++++----------
 .../mapreduce/AccumuloInputFormatTest.java      | 18 +++--
 .../accumulo/test/functional/ExamplesIT.java    | 27 ++++---
 3 files changed, 70 insertions(+), 56 deletions(-)
----------------------------------------------------------------------



[05/10] git commit: Merge branch '1.5.1-SNAPSHOT' into 1.6.0-SNAPSHOT

Posted by ec...@apache.org.
Merge branch '1.5.1-SNAPSHOT' into 1.6.0-SNAPSHOT


Project: http://git-wip-us.apache.org/repos/asf/accumulo/repo
Commit: http://git-wip-us.apache.org/repos/asf/accumulo/commit/f4600130
Tree: http://git-wip-us.apache.org/repos/asf/accumulo/tree/f4600130
Diff: http://git-wip-us.apache.org/repos/asf/accumulo/diff/f4600130

Branch: refs/heads/master
Commit: f460013047dacf23c7dfb120e8b40cd7a437eb53
Parents: dd55dc7 a550169
Author: Eric Newton <er...@gmail.com>
Authored: Tue Nov 26 15:06:06 2013 -0500
Committer: Eric Newton <er...@gmail.com>
Committed: Tue Nov 26 15:06:06 2013 -0500

----------------------------------------------------------------------

----------------------------------------------------------------------



[08/10] git commit: Merge branch '1.4.5-SNAPSHOT' into 1.5.1-SNAPSHOT

Posted by ec...@apache.org.
Merge branch '1.4.5-SNAPSHOT' into 1.5.1-SNAPSHOT


Project: http://git-wip-us.apache.org/repos/asf/accumulo/repo
Commit: http://git-wip-us.apache.org/repos/asf/accumulo/commit/374f46f4
Tree: http://git-wip-us.apache.org/repos/asf/accumulo/tree/374f46f4
Diff: http://git-wip-us.apache.org/repos/asf/accumulo/diff/374f46f4

Branch: refs/heads/master
Commit: 374f46f41a8ecee831e6ae7d6015de10007cae8e
Parents: a550169 8d39b09
Author: Eric Newton <er...@gmail.com>
Authored: Tue Nov 26 16:05:36 2013 -0500
Committer: Eric Newton <er...@gmail.com>
Committed: Tue Nov 26 16:05:36 2013 -0500

----------------------------------------------------------------------

----------------------------------------------------------------------