You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@accumulo.apache.org by ct...@apache.org on 2015/04/30 19:43:37 UTC

[01/25] accumulo git commit: ACCUMULO-3759 More Java 8 compiler warnings

Repository: accumulo
Updated Branches:
  refs/heads/1.5 5ac1b52ef -> e395bc8ce
  refs/heads/1.6 67c8b2b67 -> bbcc6da44
  refs/heads/1.7 ef2e31af3 -> 4d1acd14a
  refs/heads/master ae4fd486d -> a03f14a5c


ACCUMULO-3759 More Java 8 compiler warnings

* Fix compiler warnings in Java 8 for 1.5 branch


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

Branch: refs/heads/1.5
Commit: e395bc8ced5d740fe4a6e5d3ebb169335f64c044
Parents: 5ac1b52
Author: Christopher Tubbs <ct...@apache.org>
Authored: Thu Apr 30 12:04:50 2015 -0400
Committer: Christopher Tubbs <ct...@apache.org>
Committed: Thu Apr 30 12:04:50 2015 -0400

----------------------------------------------------------------------
 .../core/iterators/AggregatingIterator.java       | 18 ++++++++++--------
 .../aggregation/conf/AggregatorConfiguration.java |  3 +--
 .../iterators/aggregation/conf/AggregatorSet.java |  7 +++----
 .../util/shell/commands/AddSplitsCommand.java     | 18 +++++++++++++-----
 .../core/iterators/AggregatingIteratorTest.java   |  6 ++++--
 .../conf/AggregatorConfigurationTest.java         | 13 ++++++++-----
 .../org/apache/accumulo/server/master/Master.java | 16 ++++++++--------
 .../classloader/vfs/AccumuloVFSClassLoader.java   |  6 +++---
 8 files changed, 50 insertions(+), 37 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/e395bc8c/core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java b/core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java
index 28acc2b..13b2710 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java
@@ -27,7 +27,6 @@ import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.data.PartialKey;
 import org.apache.accumulo.core.data.Range;
 import org.apache.accumulo.core.data.Value;
-import org.apache.accumulo.core.iterators.aggregation.Aggregator;
 import org.apache.accumulo.core.iterators.conf.ColumnToClassMapping;
 import org.apache.accumulo.start.classloader.vfs.AccumuloVFSClassLoader;
 import org.apache.log4j.Logger;
@@ -42,7 +41,7 @@ import org.apache.log4j.Logger;
 public class AggregatingIterator implements SortedKeyValueIterator<Key,Value>, OptionDescriber {
 
   private SortedKeyValueIterator<Key,Value> iterator;
-  private ColumnToClassMapping<Aggregator> aggregators;
+  private ColumnToClassMapping<org.apache.accumulo.core.iterators.aggregation.Aggregator> aggregators;
 
   private Key workKey = new Key();
 
@@ -51,6 +50,7 @@ public class AggregatingIterator implements SortedKeyValueIterator<Key,Value>, O
   // private boolean propogateDeletes;
   private static final Logger log = Logger.getLogger(AggregatingIterator.class);
 
+  @Override
   public AggregatingIterator deepCopy(IteratorEnvironment env) {
     return new AggregatingIterator(this, env);
   }
@@ -62,7 +62,7 @@ public class AggregatingIterator implements SortedKeyValueIterator<Key,Value>, O
 
   public AggregatingIterator() {}
 
-  private void aggregateRowColumn(Aggregator aggr) throws IOException {
+  private void aggregateRowColumn(org.apache.accumulo.core.iterators.aggregation.Aggregator aggr) throws IOException {
     // this function assumes that first value is not delete
 
     if (iterator.getTopKey().isDeleted())
@@ -90,14 +90,15 @@ public class AggregatingIterator implements SortedKeyValueIterator<Key,Value>, O
   private void findTop() throws IOException {
     // check if aggregation is needed
     if (iterator.hasTop()) {
-      Aggregator aggr = aggregators.getObject(iterator.getTopKey());
+      org.apache.accumulo.core.iterators.aggregation.Aggregator aggr = aggregators.getObject(iterator.getTopKey());
       if (aggr != null) {
         aggregateRowColumn(aggr);
       }
     }
   }
 
-  public AggregatingIterator(SortedKeyValueIterator<Key,Value> iterator, ColumnToClassMapping<Aggregator> aggregators) throws IOException {
+  public AggregatingIterator(SortedKeyValueIterator<Key,Value> iterator,
+      ColumnToClassMapping<org.apache.accumulo.core.iterators.aggregation.Aggregator> aggregators) throws IOException {
     this.iterator = iterator;
     this.aggregators = aggregators;
   }
@@ -167,7 +168,8 @@ public class AggregatingIterator implements SortedKeyValueIterator<Key,Value>, O
     this.iterator = source;
 
     try {
-      this.aggregators = new ColumnToClassMapping<Aggregator>(options, Aggregator.class);
+      this.aggregators = new ColumnToClassMapping<org.apache.accumulo.core.iterators.aggregation.Aggregator>(options,
+          org.apache.accumulo.core.iterators.aggregation.Aggregator.class);
     } catch (ClassNotFoundException e) {
       log.error(e.toString());
       throw new IllegalArgumentException(e);
@@ -192,9 +194,9 @@ public class AggregatingIterator implements SortedKeyValueIterator<Key,Value>, O
       String classname = entry.getValue();
       if (classname == null)
         throw new IllegalArgumentException("classname null");
-      Class<? extends Aggregator> clazz;
+      Class<? extends org.apache.accumulo.core.iterators.aggregation.Aggregator> clazz;
       try {
-        clazz = AccumuloVFSClassLoader.loadClass(classname, Aggregator.class);
+        clazz = AccumuloVFSClassLoader.loadClass(classname, org.apache.accumulo.core.iterators.aggregation.Aggregator.class);
         clazz.newInstance();
       } catch (ClassNotFoundException e) {
         throw new IllegalArgumentException("class not found: " + classname);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/e395bc8c/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfiguration.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfiguration.java b/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfiguration.java
index 41c0374..3432cf5 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfiguration.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfiguration.java
@@ -16,14 +16,13 @@
  */
 package org.apache.accumulo.core.iterators.aggregation.conf;
 
-import org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig;
 import org.apache.hadoop.io.Text;
 
 /**
  * @deprecated since 1.4
  */
 @Deprecated
-public class AggregatorConfiguration extends PerColumnIteratorConfig {
+public class AggregatorConfiguration extends org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig {
 
   public AggregatorConfiguration(Text columnFamily, String aggClassName) {
     super(columnFamily, aggClassName);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/e395bc8c/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorSet.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorSet.java b/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorSet.java
index 26e2f11..37798b0 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorSet.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorSet.java
@@ -19,23 +19,22 @@ package org.apache.accumulo.core.iterators.aggregation.conf;
 import java.util.Map;
 
 import org.apache.accumulo.core.data.Key;
-import org.apache.accumulo.core.iterators.aggregation.Aggregator;
 import org.apache.accumulo.core.iterators.conf.ColumnToClassMapping;
 
 /**
  * @deprecated since 1.4
  */
 @Deprecated
-public class AggregatorSet extends ColumnToClassMapping<Aggregator> {
+public class AggregatorSet extends ColumnToClassMapping<org.apache.accumulo.core.iterators.aggregation.Aggregator> {
   public AggregatorSet(Map<String,String> opts) throws InstantiationException, IllegalAccessException, ClassNotFoundException {
-    super(opts, Aggregator.class);
+    super(opts, org.apache.accumulo.core.iterators.aggregation.Aggregator.class);
   }
 
   public AggregatorSet() {
     super();
   }
 
-  public Aggregator getAggregator(Key k) {
+  public org.apache.accumulo.core.iterators.aggregation.Aggregator getAggregator(Key k) {
     return getObject(k);
   }
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/e395bc8c/core/src/main/java/org/apache/accumulo/core/util/shell/commands/AddSplitsCommand.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/util/shell/commands/AddSplitsCommand.java b/core/src/main/java/org/apache/accumulo/core/util/shell/commands/AddSplitsCommand.java
index 3eab0a1..c88171a 100644
--- a/core/src/main/java/org/apache/accumulo/core/util/shell/commands/AddSplitsCommand.java
+++ b/core/src/main/java/org/apache/accumulo/core/util/shell/commands/AddSplitsCommand.java
@@ -34,6 +34,7 @@ import org.apache.hadoop.io.Text;
 public class AddSplitsCommand extends Command {
   private Option optSplitsFile, base64Opt;
 
+  @Override
   public int execute(final String fullCommand, final CommandLine cl, final Shell shellState) throws Exception {
     final String tableName = OptUtil.getTableOpt(cl, shellState);
     final boolean decode = cl.hasOption(base64Opt.getOpt());
@@ -44,11 +45,18 @@ public class AddSplitsCommand extends Command {
       final String f = cl.getOptionValue(optSplitsFile.getOpt());
 
       String line;
-      java.util.Scanner file = new java.util.Scanner(new File(f), UTF_8.name());
-      while (file.hasNextLine()) {
-        line = file.nextLine();
-        if (!line.isEmpty()) {
-          splits.add(decode ? new Text(Base64.decodeBase64(line.getBytes(UTF_8))) : new Text(line));
+      java.util.Scanner file = null;
+      try {
+        file = new java.util.Scanner(new File(f), UTF_8.name());
+        while (file.hasNextLine()) {
+          line = file.nextLine();
+          if (!line.isEmpty()) {
+            splits.add(decode ? new Text(Base64.decodeBase64(line.getBytes(UTF_8))) : new Text(line));
+          }
+        }
+      } finally {
+        if (file != null) {
+          file.close();
         }
       }
     } else {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/e395bc8c/core/src/test/java/org/apache/accumulo/core/iterators/AggregatingIteratorTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/iterators/AggregatingIteratorTest.java b/core/src/test/java/org/apache/accumulo/core/iterators/AggregatingIteratorTest.java
index 788366a..f1918b4 100644
--- a/core/src/test/java/org/apache/accumulo/core/iterators/AggregatingIteratorTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/iterators/AggregatingIteratorTest.java
@@ -31,7 +31,6 @@ import org.apache.accumulo.core.data.ByteSequence;
 import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.data.Range;
 import org.apache.accumulo.core.data.Value;
-import org.apache.accumulo.core.iterators.aggregation.Aggregator;
 import org.apache.accumulo.core.iterators.system.MultiIterator;
 import org.apache.hadoop.io.Text;
 
@@ -43,20 +42,23 @@ public class AggregatingIteratorTest extends TestCase {
 
   private static final Collection<ByteSequence> EMPTY_COL_FAMS = new ArrayList<ByteSequence>();
 
-  public static class SummationAggregator implements Aggregator {
+  public static class SummationAggregator implements org.apache.accumulo.core.iterators.aggregation.Aggregator {
 
     int sum;
 
+    @Override
     public Value aggregate() {
       return new Value((sum + "").getBytes());
     }
 
+    @Override
     public void collect(Value value) {
       int val = Integer.parseInt(value.toString());
 
       sum += val;
     }
 
+    @Override
     public void reset() {
       sum = 0;
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/e395bc8c/core/src/test/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfigurationTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfigurationTest.java b/core/src/test/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfigurationTest.java
index 1a285bc..6d666a3 100644
--- a/core/src/test/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfigurationTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfigurationTest.java
@@ -18,7 +18,6 @@ package org.apache.accumulo.core.iterators.aggregation.conf;
 
 import junit.framework.TestCase;
 
-import org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig;
 import org.apache.hadoop.io.Text;
 
 /**
@@ -46,18 +45,22 @@ public class AggregatorConfigurationTest extends TestCase {
 
   private void runTest(Text colf) {
     String encodedCols;
-    PerColumnIteratorConfig ac3 = new PerColumnIteratorConfig(colf, "com.foo.SuperAgg");
+    org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig ac3 = new org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig(colf,
+        "com.foo.SuperAgg");
     encodedCols = ac3.encodeColumns();
-    PerColumnIteratorConfig ac4 = PerColumnIteratorConfig.decodeColumns(encodedCols, "com.foo.SuperAgg");
+    org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig ac4 = org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig.decodeColumns(
+        encodedCols, "com.foo.SuperAgg");
 
     assertEquals(colf, ac4.getColumnFamily());
     assertNull(ac4.getColumnQualifier());
   }
 
   private void runTest(Text colf, Text colq) {
-    PerColumnIteratorConfig ac = new PerColumnIteratorConfig(colf, colq, "com.foo.SuperAgg");
+    org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig ac = new org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig(colf, colq,
+        "com.foo.SuperAgg");
     String encodedCols = ac.encodeColumns();
-    PerColumnIteratorConfig ac2 = PerColumnIteratorConfig.decodeColumns(encodedCols, "com.foo.SuperAgg");
+    org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig ac2 = org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig.decodeColumns(
+        encodedCols, "com.foo.SuperAgg");
 
     assertEquals(colf, ac2.getColumnFamily());
     assertEquals(colq, ac2.getColumnQualifier());

http://git-wip-us.apache.org/repos/asf/accumulo/blob/e395bc8c/server/src/main/java/org/apache/accumulo/server/master/Master.java
----------------------------------------------------------------------
diff --git a/server/src/main/java/org/apache/accumulo/server/master/Master.java b/server/src/main/java/org/apache/accumulo/server/master/Master.java
index 61ba7cf..dd94683 100644
--- a/server/src/main/java/org/apache/accumulo/server/master/Master.java
+++ b/server/src/main/java/org/apache/accumulo/server/master/Master.java
@@ -230,17 +230,17 @@ public class Master implements LiveTServerSet.Listener, TableObserver, CurrentSt
   }
 
   static final boolean X = true;
-  static final boolean _ = false;
+  static final boolean O = false;
   // @formatter:off
   static final boolean transitionOK[][] = {
       //                              INITIAL HAVE_LOCK SAFE_MODE NORMAL UNLOAD_META UNLOAD_ROOT STOP
-      /* INITIAL */                   {X,     X,        _,        _,      _,         _,          X},
-      /* HAVE_LOCK */                 {_,     X,        X,        X,      _,         _,          X},
-      /* SAFE_MODE */                 {_,     _,        X,        X,      X,         _,          X},
-      /* NORMAL */                    {_,     _,        X,        X,      X,         _,          X},
-      /* UNLOAD_METADATA_TABLETS */   {_,     _,        X,        X,      X,         X,          X},
-      /* UNLOAD_ROOT_TABLET */        {_,     _,        _,        X,      _,         X,          X},
-      /* STOP */                      {_,     _,        _,        _,      _,         _,          X}};
+      /* INITIAL */                   {X,     X,        O,        O,      O,         O,          X},
+      /* HAVE_LOCK */                 {O,     X,        X,        X,      O,         O,          X},
+      /* SAFE_MODE */                 {O,     O,        X,        X,      X,         O,          X},
+      /* NORMAL */                    {O,     O,        X,        X,      X,         O,          X},
+      /* UNLOAD_METADATA_TABLETS */   {O,     O,        X,        X,      X,         X,          X},
+      /* UNLOAD_ROOT_TABLET */        {O,     O,        O,        X,      O,         X,          X},
+      /* STOP */                      {O,     O,        O,        O,      O,         O,          X}};
   //@formatter:on
   synchronized private void setMasterState(MasterState newState) {
     if (state.equals(newState))

http://git-wip-us.apache.org/repos/asf/accumulo/blob/e395bc8c/start/src/main/java/org/apache/accumulo/start/classloader/vfs/AccumuloVFSClassLoader.java
----------------------------------------------------------------------
diff --git a/start/src/main/java/org/apache/accumulo/start/classloader/vfs/AccumuloVFSClassLoader.java b/start/src/main/java/org/apache/accumulo/start/classloader/vfs/AccumuloVFSClassLoader.java
index 7fa17d6..0abc79a 100644
--- a/start/src/main/java/org/apache/accumulo/start/classloader/vfs/AccumuloVFSClassLoader.java
+++ b/start/src/main/java/org/apache/accumulo/start/classloader/vfs/AccumuloVFSClassLoader.java
@@ -62,6 +62,7 @@ public class AccumuloVFSClassLoader {
 
   public static class AccumuloVFSClassLoaderShutdownThread implements Runnable {
 
+    @Override
     public void run() {
       try {
         AccumuloVFSClassLoader.close();
@@ -100,7 +101,7 @@ public class AccumuloVFSClassLoader {
 
   public synchronized static <U> Class<? extends U> loadClass(String classname, Class<U> extension) throws ClassNotFoundException {
     try {
-      return (Class<? extends U>) getClassLoader().loadClass(classname).asSubclass(extension);
+      return getClassLoader().loadClass(classname).asSubclass(extension);
     } catch (IOException e) {
       throw new ClassNotFoundException("IO Error loading class " + classname, e);
     }
@@ -326,10 +327,9 @@ public class AccumuloVFSClassLoader {
 
         if (classLoader instanceof URLClassLoader) {
           // If VFS class loader enabled, but no contexts defined.
-          URLClassLoader ucl = (URLClassLoader) classLoader;
           out.print("Level " + classLoaderDescription + " URL classpath items are:");
 
-          for (URL u : ucl.getURLs()) {
+          for (URL u : ((URLClassLoader) classLoader).getURLs()) {
             out.print("\t" + u.toExternalForm());
           }
 


[24/25] accumulo git commit: Merge branch '1.6' into 1.7

Posted by ct...@apache.org.
Merge branch '1.6' into 1.7

Conflicts:
	core/src/main/java/org/apache/accumulo/core/master/thrift/MasterClientService.java
	core/src/main/scripts/generate-thrift.sh
	core/src/test/java/org/apache/accumulo/core/iterators/AggregatingIteratorTest.java
	pom.xml
	server/tracer/src/main/scripts/generate-thrift.sh
	shell/src/main/java/org/apache/accumulo/shell/commands/AddSplitsCommand.java
	trace/src/main/java/org/apache/accumulo/trace/thrift/TInfo.java


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

Branch: refs/heads/master
Commit: 4d1acd14a1e864188e28a90e4c84f0389b052da4
Parents: ef2e31a bbcc6da
Author: Christopher Tubbs <ct...@apache.org>
Authored: Thu Apr 30 13:42:38 2015 -0400
Committer: Christopher Tubbs <ct...@apache.org>
Committed: Thu Apr 30 13:42:38 2015 -0400

----------------------------------------------------------------------
 core/src/main/scripts/generate-thrift.sh | 6 +++---
 pom.xml                                  | 6 ++++--
 2 files changed, 7 insertions(+), 5 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/4d1acd14/core/src/main/scripts/generate-thrift.sh
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/accumulo/blob/4d1acd14/pom.xml
----------------------------------------------------------------------
diff --cc pom.xml
index f680f84,9249a5b..c74ad2a
--- a/pom.xml
+++ b/pom.xml
@@@ -119,15 -118,15 +119,17 @@@
      <accumulo.release.version>${project.version}</accumulo.release.version>
      <!-- bouncycastle version for test dependencies -->
      <bouncycastle.version>1.50</bouncycastle.version>
+     <!-- findbugs-maven-plugin won't work on jdk8 or later; set to 3.0.0 or newer -->
 -    <findbugs.version>2.5.5</findbugs.version>
++    <findbugs.version>3.0.0</findbugs.version>
      <!-- surefire/failsafe plugin option -->
      <forkCount>1</forkCount>
 -    <!-- overwritten in profiles hadoop-1 or hadoop-2 -->
 +    <!-- overwritten in hadoop profiles -->
      <hadoop.version>2.2.0</hadoop.version>
 +    <htrace.version>3.1.0-incubating</htrace.version>
      <httpclient.version>3.1</httpclient.version>
 -    <java.ver>1.6</java.ver>
 -    <jetty.version>8.1.15.v20140411</jetty.version>
 +    <jetty.version>9.1.5.v20140505</jetty.version>
 +    <maven.compiler.source>1.7</maven.compiler.source>
 +    <maven.compiler.target>1.7</maven.compiler.target>
      <!-- the maven-release-plugin makes this recommendation, due to plugin bugs -->
      <maven.min-version>3.0.4</maven.min-version>
      <!-- surefire/failsafe plugin option -->


[05/25] accumulo git commit: Merge branch '1.5' into 1.6

Posted by ct...@apache.org.
Merge branch '1.5' into 1.6

Conflicts:
	core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java
	core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorSet.java
	server/src/main/java/org/apache/accumulo/server/master/Master.java


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

Branch: refs/heads/1.7
Commit: b636ff2cc614f8112207d369acd38a83770397e3
Parents: 67c8b2b e395bc8
Author: Christopher Tubbs <ct...@apache.org>
Authored: Thu Apr 30 12:10:44 2015 -0400
Committer: Christopher Tubbs <ct...@apache.org>
Committed: Thu Apr 30 12:10:44 2015 -0400

----------------------------------------------------------------------
 .../core/iterators/AggregatingIterator.java       | 18 ++++++++++--------
 .../aggregation/conf/AggregatorConfiguration.java |  3 +--
 .../iterators/aggregation/conf/AggregatorSet.java |  7 +++----
 .../util/shell/commands/AddSplitsCommand.java     | 17 ++++++++++++-----
 .../core/iterators/AggregatingIteratorTest.java   |  6 ++++--
 .../conf/AggregatorConfigurationTest.java         | 13 ++++++++-----
 6 files changed, 38 insertions(+), 26 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/b636ff2c/core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java
----------------------------------------------------------------------
diff --cc core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java
index fd5525b,13b2710..eb45fac
--- a/core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java
@@@ -168,10 -168,8 +169,11 @@@ public class AggregatingIterator implem
      this.iterator = source;
  
      try {
 +      String context = null;
 +      if (null != env)
 +        context = env.getConfig().get(Property.TABLE_CLASSPATH);
-       this.aggregators = new ColumnToClassMapping<Aggregator>(options, Aggregator.class, context);
+       this.aggregators = new ColumnToClassMapping<org.apache.accumulo.core.iterators.aggregation.Aggregator>(options,
 -          org.apache.accumulo.core.iterators.aggregation.Aggregator.class);
++          org.apache.accumulo.core.iterators.aggregation.Aggregator.class, context);
      } catch (ClassNotFoundException e) {
        log.error(e.toString());
        throw new IllegalArgumentException(e);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b636ff2c/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorSet.java
----------------------------------------------------------------------
diff --cc core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorSet.java
index c874cc8,37798b0..d6545ac
--- a/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorSet.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorSet.java
@@@ -27,9 -25,9 +26,9 @@@ import org.apache.accumulo.core.iterato
   * @deprecated since 1.4
   */
  @Deprecated
- public class AggregatorSet extends ColumnToClassMapping<Aggregator> {
+ public class AggregatorSet extends ColumnToClassMapping<org.apache.accumulo.core.iterators.aggregation.Aggregator> {
 -  public AggregatorSet(Map<String,String> opts) throws InstantiationException, IllegalAccessException, ClassNotFoundException {
 +  public AggregatorSet(Map<String,String> opts) throws InstantiationException, IllegalAccessException, ClassNotFoundException, IOException {
-     super(opts, Aggregator.class);
+     super(opts, org.apache.accumulo.core.iterators.aggregation.Aggregator.class);
    }
  
    public AggregatorSet() {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b636ff2c/core/src/main/java/org/apache/accumulo/core/util/shell/commands/AddSplitsCommand.java
----------------------------------------------------------------------
diff --cc core/src/main/java/org/apache/accumulo/core/util/shell/commands/AddSplitsCommand.java
index efbbcbe,c88171a..18298dd
--- a/core/src/main/java/org/apache/accumulo/core/util/shell/commands/AddSplitsCommand.java
+++ b/core/src/main/java/org/apache/accumulo/core/util/shell/commands/AddSplitsCommand.java
@@@ -45,14 -45,20 +45,21 @@@ public class AddSplitsCommand extends C
        final String f = cl.getOptionValue(optSplitsFile.getOpt());
  
        String line;
-       java.util.Scanner file = new java.util.Scanner(new File(f), UTF_8.name());
-       while (file.hasNextLine()) {
-         line = file.nextLine();
-         if (!line.isEmpty()) {
-           splits.add(decode ? new Text(Base64.decodeBase64(line.getBytes(UTF_8))) : new Text(line));
+       java.util.Scanner file = null;
+       try {
+         file = new java.util.Scanner(new File(f), UTF_8.name());
+         while (file.hasNextLine()) {
+           line = file.nextLine();
+           if (!line.isEmpty()) {
+             splits.add(decode ? new Text(Base64.decodeBase64(line.getBytes(UTF_8))) : new Text(line));
+           }
+         }
+       } finally {
+         if (file != null) {
+           file.close();
          }
        }
 +      file.close();
      } else {
        if (cl.getArgList().isEmpty()) {
          throw new MissingArgumentException("No split points specified");


[18/25] accumulo git commit: ACCUMULO-3759 More build warnings on Java 8

Posted by ct...@apache.org.
http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Condition.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Condition.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Condition.java
index 8dd28cf..c4b3c07 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Condition.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Condition.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class Condition implements org.apache.thrift.TBase<Condition, Condition._Fields>, java.io.Serializable, Cloneable, Comparable<Condition> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class Condition implements org.apache.thrift.TBase<Condition, Condition._Fields>, java.io.Serializable, Cloneable, Comparable<Condition> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("Condition");
 
   private static final org.apache.thrift.protocol.TField COLUMN_FIELD_DESC = new org.apache.thrift.protocol.TField("column", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -68,7 +68,7 @@ import org.slf4j.LoggerFactory;
   public List<IteratorSetting> iterators; // optional
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     COLUMN((short)1, "column"),
     TIMESTAMP((short)2, "timestamp"),
     VALUE((short)3, "value"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalStatus.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalStatus.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalStatus.java
index 55f0e62..515c416 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalStatus.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalStatus.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum ConditionalStatus implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum ConditionalStatus implements org.apache.thrift.TEnum {
   ACCEPTED(0),
   REJECTED(1),
   VIOLATED(2),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalUpdates.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalUpdates.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalUpdates.java
index 71806fe..551e996 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalUpdates.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalUpdates.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ConditionalUpdates implements org.apache.thrift.TBase<ConditionalUpdates, ConditionalUpdates._Fields>, java.io.Serializable, Cloneable, Comparable<ConditionalUpdates> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ConditionalUpdates implements org.apache.thrift.TBase<ConditionalUpdates, ConditionalUpdates._Fields>, java.io.Serializable, Cloneable, Comparable<ConditionalUpdates> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ConditionalUpdates");
 
   private static final org.apache.thrift.protocol.TField CONDITIONS_FIELD_DESC = new org.apache.thrift.protocol.TField("conditions", org.apache.thrift.protocol.TType.LIST, (short)2);
@@ -64,7 +64,7 @@ import org.slf4j.LoggerFactory;
   public List<ColumnUpdate> updates; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     CONDITIONS((short)2, "conditions"),
     UPDATES((short)3, "updates");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalWriterOptions.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalWriterOptions.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalWriterOptions.java
index bb4ad51..99c5172 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalWriterOptions.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalWriterOptions.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ConditionalWriterOptions implements org.apache.thrift.TBase<ConditionalWriterOptions, ConditionalWriterOptions._Fields>, java.io.Serializable, Cloneable, Comparable<ConditionalWriterOptions> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ConditionalWriterOptions implements org.apache.thrift.TBase<ConditionalWriterOptions, ConditionalWriterOptions._Fields>, java.io.Serializable, Cloneable, Comparable<ConditionalWriterOptions> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ConditionalWriterOptions");
 
   private static final org.apache.thrift.protocol.TField MAX_MEMORY_FIELD_DESC = new org.apache.thrift.protocol.TField("maxMemory", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -68,7 +68,7 @@ import org.slf4j.LoggerFactory;
   public Set<ByteBuffer> authorizations; // optional
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     MAX_MEMORY((short)1, "maxMemory"),
     TIMEOUT_MS((short)2, "timeoutMs"),
     THREADS((short)3, "threads"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/DiskUsage.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/DiskUsage.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/DiskUsage.java
index 36080ed..82a886d 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/DiskUsage.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/DiskUsage.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class DiskUsage implements org.apache.thrift.TBase<DiskUsage, DiskUsage._Fields>, java.io.Serializable, Cloneable, Comparable<DiskUsage> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class DiskUsage implements org.apache.thrift.TBase<DiskUsage, DiskUsage._Fields>, java.io.Serializable, Cloneable, Comparable<DiskUsage> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("DiskUsage");
 
   private static final org.apache.thrift.protocol.TField TABLES_FIELD_DESC = new org.apache.thrift.protocol.TField("tables", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -64,7 +64,7 @@ import org.slf4j.LoggerFactory;
   public long usage; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     TABLES((short)1, "tables"),
     USAGE((short)2, "usage");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/IteratorScope.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/IteratorScope.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/IteratorScope.java
index bafd525..0fc8de8 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/IteratorScope.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/IteratorScope.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum IteratorScope implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum IteratorScope implements org.apache.thrift.TEnum {
   MINC(0),
   MAJC(1),
   SCAN(2);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/IteratorSetting.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/IteratorSetting.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/IteratorSetting.java
index 1956b9a..eabc686 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/IteratorSetting.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/IteratorSetting.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class IteratorSetting implements org.apache.thrift.TBase<IteratorSetting, IteratorSetting._Fields>, java.io.Serializable, Cloneable, Comparable<IteratorSetting> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class IteratorSetting implements org.apache.thrift.TBase<IteratorSetting, IteratorSetting._Fields>, java.io.Serializable, Cloneable, Comparable<IteratorSetting> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("IteratorSetting");
 
   private static final org.apache.thrift.protocol.TField PRIORITY_FIELD_DESC = new org.apache.thrift.protocol.TField("priority", org.apache.thrift.protocol.TType.I32, (short)1);
@@ -68,7 +68,7 @@ import org.slf4j.LoggerFactory;
   public Map<String,String> properties; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     PRIORITY((short)1, "priority"),
     NAME((short)2, "name"),
     ITERATOR_CLASS((short)3, "iteratorClass"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Key.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Key.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Key.java
index ecba9d1..6984cf2 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Key.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Key.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class Key implements org.apache.thrift.TBase<Key, Key._Fields>, java.io.Serializable, Cloneable, Comparable<Key> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class Key implements org.apache.thrift.TBase<Key, Key._Fields>, java.io.Serializable, Cloneable, Comparable<Key> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("Key");
 
   private static final org.apache.thrift.protocol.TField ROW_FIELD_DESC = new org.apache.thrift.protocol.TField("row", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -70,7 +70,7 @@ import org.slf4j.LoggerFactory;
   public long timestamp; // optional
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     ROW((short)1, "row"),
     COL_FAMILY((short)2, "colFamily"),
     COL_QUALIFIER((short)3, "colQualifier"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyExtent.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyExtent.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyExtent.java
index f9c9e4c..1136284 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyExtent.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyExtent.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class KeyExtent implements org.apache.thrift.TBase<KeyExtent, KeyExtent._Fields>, java.io.Serializable, Cloneable, Comparable<KeyExtent> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class KeyExtent implements org.apache.thrift.TBase<KeyExtent, KeyExtent._Fields>, java.io.Serializable, Cloneable, Comparable<KeyExtent> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("KeyExtent");
 
   private static final org.apache.thrift.protocol.TField TABLE_ID_FIELD_DESC = new org.apache.thrift.protocol.TField("tableId", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -66,7 +66,7 @@ import org.slf4j.LoggerFactory;
   public ByteBuffer prevEndRow; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     TABLE_ID((short)1, "tableId"),
     END_ROW((short)2, "endRow"),
     PREV_END_ROW((short)3, "prevEndRow");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyValue.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyValue.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyValue.java
index 52bfbd1..76d71b5 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyValue.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyValue.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class KeyValue implements org.apache.thrift.TBase<KeyValue, KeyValue._Fields>, java.io.Serializable, Cloneable, Comparable<KeyValue> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class KeyValue implements org.apache.thrift.TBase<KeyValue, KeyValue._Fields>, java.io.Serializable, Cloneable, Comparable<KeyValue> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("KeyValue");
 
   private static final org.apache.thrift.protocol.TField KEY_FIELD_DESC = new org.apache.thrift.protocol.TField("key", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -64,7 +64,7 @@ import org.slf4j.LoggerFactory;
   public ByteBuffer value; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     KEY((short)1, "key"),
     VALUE((short)2, "value");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyValueAndPeek.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyValueAndPeek.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyValueAndPeek.java
index 1993d01..88b0c3f 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyValueAndPeek.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyValueAndPeek.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class KeyValueAndPeek implements org.apache.thrift.TBase<KeyValueAndPeek, KeyValueAndPeek._Fields>, java.io.Serializable, Cloneable, Comparable<KeyValueAndPeek> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class KeyValueAndPeek implements org.apache.thrift.TBase<KeyValueAndPeek, KeyValueAndPeek._Fields>, java.io.Serializable, Cloneable, Comparable<KeyValueAndPeek> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("KeyValueAndPeek");
 
   private static final org.apache.thrift.protocol.TField KEY_VALUE_FIELD_DESC = new org.apache.thrift.protocol.TField("keyValue", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -64,7 +64,7 @@ import org.slf4j.LoggerFactory;
   public boolean hasNext; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     KEY_VALUE((short)1, "keyValue"),
     HAS_NEXT((short)2, "hasNext");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/MutationsRejectedException.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/MutationsRejectedException.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/MutationsRejectedException.java
index c0f8740..e5dfda1 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/MutationsRejectedException.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/MutationsRejectedException.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class MutationsRejectedException extends TException implements org.apache.thrift.TBase<MutationsRejectedException, MutationsRejectedException._Fields>, java.io.Serializable, Cloneable, Comparable<MutationsRejectedException> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class MutationsRejectedException extends TException implements org.apache.thrift.TBase<MutationsRejectedException, MutationsRejectedException._Fields>, java.io.Serializable, Cloneable, Comparable<MutationsRejectedException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("MutationsRejectedException");
 
   private static final org.apache.thrift.protocol.TField MSG_FIELD_DESC = new org.apache.thrift.protocol.TField("msg", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public String msg; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     MSG((short)1, "msg");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/NoMoreEntriesException.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/NoMoreEntriesException.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/NoMoreEntriesException.java
index b0a543a..d67bcd2 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/NoMoreEntriesException.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/NoMoreEntriesException.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class NoMoreEntriesException extends TException implements org.apache.thrift.TBase<NoMoreEntriesException, NoMoreEntriesException._Fields>, java.io.Serializable, Cloneable, Comparable<NoMoreEntriesException> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class NoMoreEntriesException extends TException implements org.apache.thrift.TBase<NoMoreEntriesException, NoMoreEntriesException._Fields>, java.io.Serializable, Cloneable, Comparable<NoMoreEntriesException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("NoMoreEntriesException");
 
   private static final org.apache.thrift.protocol.TField MSG_FIELD_DESC = new org.apache.thrift.protocol.TField("msg", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public String msg; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     MSG((short)1, "msg");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/PartialKey.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/PartialKey.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/PartialKey.java
index 1c9bfc4..2a0f269 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/PartialKey.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/PartialKey.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum PartialKey implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum PartialKey implements org.apache.thrift.TEnum {
   ROW(0),
   ROW_COLFAM(1),
   ROW_COLFAM_COLQUAL(2),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Range.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Range.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Range.java
index b1f505f..bc66c6b 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Range.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Range.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class Range implements org.apache.thrift.TBase<Range, Range._Fields>, java.io.Serializable, Cloneable, Comparable<Range> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class Range implements org.apache.thrift.TBase<Range, Range._Fields>, java.io.Serializable, Cloneable, Comparable<Range> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("Range");
 
   private static final org.apache.thrift.protocol.TField START_FIELD_DESC = new org.apache.thrift.protocol.TField("start", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -68,7 +68,7 @@ import org.slf4j.LoggerFactory;
   public boolean stopInclusive; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     START((short)1, "start"),
     START_INCLUSIVE((short)2, "startInclusive"),
     STOP((short)3, "stop"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanColumn.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanColumn.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanColumn.java
index 101d720..296c885 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanColumn.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanColumn.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ScanColumn implements org.apache.thrift.TBase<ScanColumn, ScanColumn._Fields>, java.io.Serializable, Cloneable, Comparable<ScanColumn> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ScanColumn implements org.apache.thrift.TBase<ScanColumn, ScanColumn._Fields>, java.io.Serializable, Cloneable, Comparable<ScanColumn> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ScanColumn");
 
   private static final org.apache.thrift.protocol.TField COL_FAMILY_FIELD_DESC = new org.apache.thrift.protocol.TField("colFamily", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -64,7 +64,7 @@ import org.slf4j.LoggerFactory;
   public ByteBuffer colQualifier; // optional
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     COL_FAMILY((short)1, "colFamily"),
     COL_QUALIFIER((short)2, "colQualifier");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanOptions.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanOptions.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanOptions.java
index 1e025ba..047daa0 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanOptions.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanOptions.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ScanOptions implements org.apache.thrift.TBase<ScanOptions, ScanOptions._Fields>, java.io.Serializable, Cloneable, Comparable<ScanOptions> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ScanOptions implements org.apache.thrift.TBase<ScanOptions, ScanOptions._Fields>, java.io.Serializable, Cloneable, Comparable<ScanOptions> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ScanOptions");
 
   private static final org.apache.thrift.protocol.TField AUTHORIZATIONS_FIELD_DESC = new org.apache.thrift.protocol.TField("authorizations", org.apache.thrift.protocol.TType.SET, (short)1);
@@ -70,7 +70,7 @@ import org.slf4j.LoggerFactory;
   public int bufferSize; // optional
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     AUTHORIZATIONS((short)1, "authorizations"),
     RANGE((short)2, "range"),
     COLUMNS((short)3, "columns"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanResult.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanResult.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanResult.java
index 02e1fe0..3775e7d 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanResult.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanResult.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ScanResult implements org.apache.thrift.TBase<ScanResult, ScanResult._Fields>, java.io.Serializable, Cloneable, Comparable<ScanResult> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ScanResult implements org.apache.thrift.TBase<ScanResult, ScanResult._Fields>, java.io.Serializable, Cloneable, Comparable<ScanResult> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ScanResult");
 
   private static final org.apache.thrift.protocol.TField RESULTS_FIELD_DESC = new org.apache.thrift.protocol.TField("results", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -64,7 +64,7 @@ import org.slf4j.LoggerFactory;
   public boolean more; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     RESULTS((short)1, "results"),
     MORE((short)2, "more");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanState.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanState.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanState.java
index 46608d1..127d147 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanState.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanState.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum ScanState implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum ScanState implements org.apache.thrift.TEnum {
   IDLE(0),
   RUNNING(1),
   QUEUED(2);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanType.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanType.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanType.java
index e153997..f417110 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanType.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanType.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum ScanType implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum ScanType implements org.apache.thrift.TEnum {
   SINGLE(0),
   BATCH(1);
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/SystemPermission.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/SystemPermission.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/SystemPermission.java
index 40e61d0..929b83a 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/SystemPermission.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/SystemPermission.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum SystemPermission implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum SystemPermission implements org.apache.thrift.TEnum {
   GRANT(0),
   CREATE_TABLE(1),
   DROP_TABLE(2),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TableExistsException.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TableExistsException.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TableExistsException.java
index 031de3a..9e3cf9c 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TableExistsException.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TableExistsException.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TableExistsException extends TException implements org.apache.thrift.TBase<TableExistsException, TableExistsException._Fields>, java.io.Serializable, Cloneable, Comparable<TableExistsException> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TableExistsException extends TException implements org.apache.thrift.TBase<TableExistsException, TableExistsException._Fields>, java.io.Serializable, Cloneable, Comparable<TableExistsException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TableExistsException");
 
   private static final org.apache.thrift.protocol.TField MSG_FIELD_DESC = new org.apache.thrift.protocol.TField("msg", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public String msg; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     MSG((short)1, "msg");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TableNotFoundException.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TableNotFoundException.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TableNotFoundException.java
index 6e8ec11..f12059b 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TableNotFoundException.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TableNotFoundException.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TableNotFoundException extends TException implements org.apache.thrift.TBase<TableNotFoundException, TableNotFoundException._Fields>, java.io.Serializable, Cloneable, Comparable<TableNotFoundException> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TableNotFoundException extends TException implements org.apache.thrift.TBase<TableNotFoundException, TableNotFoundException._Fields>, java.io.Serializable, Cloneable, Comparable<TableNotFoundException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TableNotFoundException");
 
   private static final org.apache.thrift.protocol.TField MSG_FIELD_DESC = new org.apache.thrift.protocol.TField("msg", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public String msg; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     MSG((short)1, "msg");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TablePermission.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TablePermission.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TablePermission.java
index f36d933..04882fa 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TablePermission.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TablePermission.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum TablePermission implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum TablePermission implements org.apache.thrift.TEnum {
   READ(2),
   WRITE(3),
   BULK_IMPORT(4),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TimeType.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TimeType.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TimeType.java
index b497ecc..32564e0 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TimeType.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TimeType.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum TimeType implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum TimeType implements org.apache.thrift.TEnum {
   LOGICAL(0),
   MILLIS(1);
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/UnknownScanner.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/UnknownScanner.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/UnknownScanner.java
index a324af8..f6a4b1e 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/UnknownScanner.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/UnknownScanner.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class UnknownScanner extends TException implements org.apache.thrift.TBase<UnknownScanner, UnknownScanner._Fields>, java.io.Serializable, Cloneable, Comparable<UnknownScanner> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class UnknownScanner extends TException implements org.apache.thrift.TBase<UnknownScanner, UnknownScanner._Fields>, java.io.Serializable, Cloneable, Comparable<UnknownScanner> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("UnknownScanner");
 
   private static final org.apache.thrift.protocol.TField MSG_FIELD_DESC = new org.apache.thrift.protocol.TField("msg", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public String msg; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     MSG((short)1, "msg");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/UnknownWriter.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/UnknownWriter.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/UnknownWriter.java
index 5b83ae5..661aa1b 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/UnknownWriter.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/UnknownWriter.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class UnknownWriter extends TException implements org.apache.thrift.TBase<UnknownWriter, UnknownWriter._Fields>, java.io.Serializable, Cloneable, Comparable<UnknownWriter> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class UnknownWriter extends TException implements org.apache.thrift.TBase<UnknownWriter, UnknownWriter._Fields>, java.io.Serializable, Cloneable, Comparable<UnknownWriter> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("UnknownWriter");
 
   private static final org.apache.thrift.protocol.TField MSG_FIELD_DESC = new org.apache.thrift.protocol.TField("msg", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public String msg; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     MSG((short)1, "msg");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/WriterOptions.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/WriterOptions.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/WriterOptions.java
index 5f000a8..a57b995 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/WriterOptions.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/WriterOptions.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class WriterOptions implements org.apache.thrift.TBase<WriterOptions, WriterOptions._Fields>, java.io.Serializable, Cloneable, Comparable<WriterOptions> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class WriterOptions implements org.apache.thrift.TBase<WriterOptions, WriterOptions._Fields>, java.io.Serializable, Cloneable, Comparable<WriterOptions> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("WriterOptions");
 
   private static final org.apache.thrift.protocol.TField MAX_MEMORY_FIELD_DESC = new org.apache.thrift.protocol.TField("maxMemory", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -68,7 +68,7 @@ import org.slf4j.LoggerFactory;
   public int threads; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     MAX_MEMORY((short)1, "maxMemory"),
     LATENCY_MS((short)2, "latencyMs"),
     TIMEOUT_MS((short)3, "timeoutMs"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/trace/src/main/java/org/apache/accumulo/trace/thrift/RemoteSpan.java
----------------------------------------------------------------------
diff --git a/trace/src/main/java/org/apache/accumulo/trace/thrift/RemoteSpan.java b/trace/src/main/java/org/apache/accumulo/trace/thrift/RemoteSpan.java
index 416ae17..ffd66c8 100644
--- a/trace/src/main/java/org/apache/accumulo/trace/thrift/RemoteSpan.java
+++ b/trace/src/main/java/org/apache/accumulo/trace/thrift/RemoteSpan.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class RemoteSpan implements org.apache.thrift.TBase<RemoteSpan, RemoteSpan._Fields>, java.io.Serializable, Cloneable, Comparable<RemoteSpan> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class RemoteSpan implements org.apache.thrift.TBase<RemoteSpan, RemoteSpan._Fields>, java.io.Serializable, Cloneable, Comparable<RemoteSpan> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("RemoteSpan");
 
   private static final org.apache.thrift.protocol.TField SENDER_FIELD_DESC = new org.apache.thrift.protocol.TField("sender", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -78,7 +78,7 @@ import org.slf4j.LoggerFactory;
   public Map<String,String> data; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     SENDER((short)1, "sender"),
     SVC((short)2, "svc"),
     TRACE_ID((short)3, "traceId"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/trace/src/main/java/org/apache/accumulo/trace/thrift/SpanReceiver.java
----------------------------------------------------------------------
diff --git a/trace/src/main/java/org/apache/accumulo/trace/thrift/SpanReceiver.java b/trace/src/main/java/org/apache/accumulo/trace/thrift/SpanReceiver.java
index 4fe4c38..19b260f 100644
--- a/trace/src/main/java/org/apache/accumulo/trace/thrift/SpanReceiver.java
+++ b/trace/src/main/java/org/apache/accumulo/trace/thrift/SpanReceiver.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class SpanReceiver {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class SpanReceiver {
 
   public interface Iface {
 
@@ -240,7 +240,7 @@ import org.slf4j.LoggerFactory;
     public RemoteSpan span; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SPAN((short)1, "span");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/trace/src/main/java/org/apache/accumulo/trace/thrift/TInfo.java
----------------------------------------------------------------------
diff --git a/trace/src/main/java/org/apache/accumulo/trace/thrift/TInfo.java b/trace/src/main/java/org/apache/accumulo/trace/thrift/TInfo.java
index 8e71aea..65fad13 100644
--- a/trace/src/main/java/org/apache/accumulo/trace/thrift/TInfo.java
+++ b/trace/src/main/java/org/apache/accumulo/trace/thrift/TInfo.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TInfo implements org.apache.thrift.TBase<TInfo, TInfo._Fields>, java.io.Serializable, Cloneable, Comparable<TInfo> {
+@SuppressWarnings({"unchecked", "rawtypes", "unused"}) public class TInfo implements org.apache.thrift.TBase<TInfo, TInfo._Fields>, java.io.Serializable, Cloneable, Comparable<TInfo> {
 
   private static final long serialVersionUID = -4659975753252858243l; // See ACCUMULO-3132
 
@@ -67,7 +67,7 @@ import org.slf4j.LoggerFactory;
   public long parentId; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     TRACE_ID((short)1, "traceId"),
     PARENT_ID((short)2, "parentId");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/trace/src/main/java/org/apache/accumulo/trace/thrift/TestService.java
----------------------------------------------------------------------
diff --git a/trace/src/main/java/org/apache/accumulo/trace/thrift/TestService.java b/trace/src/main/java/org/apache/accumulo/trace/thrift/TestService.java
index da5d64f..f1f5f9e 100644
--- a/trace/src/main/java/org/apache/accumulo/trace/thrift/TestService.java
+++ b/trace/src/main/java/org/apache/accumulo/trace/thrift/TestService.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TestService {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TestService {
 
   public interface Iface {
 
@@ -284,7 +284,7 @@ import org.slf4j.LoggerFactory;
     public String message; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       MESSAGE((short)2, "message");
 
@@ -741,7 +741,7 @@ import org.slf4j.LoggerFactory;
     public boolean success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/trace/src/main/scripts/generate-thrift.sh
----------------------------------------------------------------------
diff --git a/trace/src/main/scripts/generate-thrift.sh b/trace/src/main/scripts/generate-thrift.sh
index 0bb0005..c25782e 100755
--- a/trace/src/main/scripts/generate-thrift.sh
+++ b/trace/src/main/scripts/generate-thrift.sh
@@ -27,3 +27,7 @@ sed -i -e 's/\(public class TInfo .*\)$/\1\
 \
   private static final long serialVersionUID = -4659975753252858243l; \/\/ See ACCUMULO-3132\
 /' src/main/java/org/apache/accumulo/trace/thrift/TInfo.java
+
+# Remove unnecessary SuppressWarnings
+sed -i -e 's/"serial", //' src/main/java/org/apache/accumulo/trace/thrift/TInfo.java
+


[16/25] accumulo git commit: ACCUMULO-3759 More build warnings on Java 8

Posted by ct...@apache.org.
http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/gc/thrift/GCMonitorService.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/gc/thrift/GCMonitorService.java b/core/src/main/java/org/apache/accumulo/core/gc/thrift/GCMonitorService.java
index 9d7ba57..042093a 100644
--- a/core/src/main/java/org/apache/accumulo/core/gc/thrift/GCMonitorService.java
+++ b/core/src/main/java/org/apache/accumulo/core/gc/thrift/GCMonitorService.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class GCMonitorService {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class GCMonitorService {
 
   public interface Iface {
 
@@ -295,7 +295,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.security.thrift.TCredentials credentials; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       CREDENTIALS((short)1, "credentials");
 
@@ -759,7 +759,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/gc/thrift/GCStatus.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/gc/thrift/GCStatus.java b/core/src/main/java/org/apache/accumulo/core/gc/thrift/GCStatus.java
index 7c90b7a..9d6ade6 100644
--- a/core/src/main/java/org/apache/accumulo/core/gc/thrift/GCStatus.java
+++ b/core/src/main/java/org/apache/accumulo/core/gc/thrift/GCStatus.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class GCStatus implements org.apache.thrift.TBase<GCStatus, GCStatus._Fields>, java.io.Serializable, Cloneable, Comparable<GCStatus> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class GCStatus implements org.apache.thrift.TBase<GCStatus, GCStatus._Fields>, java.io.Serializable, Cloneable, Comparable<GCStatus> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("GCStatus");
 
   private static final org.apache.thrift.protocol.TField LAST_FIELD_DESC = new org.apache.thrift.protocol.TField("last", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -68,7 +68,7 @@ import org.slf4j.LoggerFactory;
   public GcCycleStats currentLog; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     LAST((short)1, "last"),
     LAST_LOG((short)2, "lastLog"),
     CURRENT((short)3, "current"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/gc/thrift/GcCycleStats.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/gc/thrift/GcCycleStats.java b/core/src/main/java/org/apache/accumulo/core/gc/thrift/GcCycleStats.java
index a76c14c..83dc826 100644
--- a/core/src/main/java/org/apache/accumulo/core/gc/thrift/GcCycleStats.java
+++ b/core/src/main/java/org/apache/accumulo/core/gc/thrift/GcCycleStats.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class GcCycleStats implements org.apache.thrift.TBase<GcCycleStats, GcCycleStats._Fields>, java.io.Serializable, Cloneable, Comparable<GcCycleStats> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class GcCycleStats implements org.apache.thrift.TBase<GcCycleStats, GcCycleStats._Fields>, java.io.Serializable, Cloneable, Comparable<GcCycleStats> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("GcCycleStats");
 
   private static final org.apache.thrift.protocol.TField STARTED_FIELD_DESC = new org.apache.thrift.protocol.TField("started", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -72,7 +72,7 @@ import org.slf4j.LoggerFactory;
   public long errors; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     STARTED((short)1, "started"),
     FINISHED((short)2, "finished"),
     CANDIDATES((short)3, "candidates"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/Compacting.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/Compacting.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/Compacting.java
index d99d41f..5b1b9cc 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/Compacting.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/Compacting.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class Compacting implements org.apache.thrift.TBase<Compacting, Compacting._Fields>, java.io.Serializable, Cloneable, Comparable<Compacting> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class Compacting implements org.apache.thrift.TBase<Compacting, Compacting._Fields>, java.io.Serializable, Cloneable, Comparable<Compacting> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("Compacting");
 
   private static final org.apache.thrift.protocol.TField RUNNING_FIELD_DESC = new org.apache.thrift.protocol.TField("running", org.apache.thrift.protocol.TType.I32, (short)1);
@@ -64,7 +64,7 @@ import org.slf4j.LoggerFactory;
   public int queued; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     RUNNING((short)1, "running"),
     QUEUED((short)2, "queued");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/DeadServer.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/DeadServer.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/DeadServer.java
index e428589..1cbe5f7 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/DeadServer.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/DeadServer.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class DeadServer implements org.apache.thrift.TBase<DeadServer, DeadServer._Fields>, java.io.Serializable, Cloneable, Comparable<DeadServer> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class DeadServer implements org.apache.thrift.TBase<DeadServer, DeadServer._Fields>, java.io.Serializable, Cloneable, Comparable<DeadServer> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("DeadServer");
 
   private static final org.apache.thrift.protocol.TField SERVER_FIELD_DESC = new org.apache.thrift.protocol.TField("server", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -66,7 +66,7 @@ import org.slf4j.LoggerFactory;
   public String status; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     SERVER((short)1, "server"),
     LAST_STATUS((short)2, "lastStatus"),
     STATUS((short)3, "status");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/FateOperation.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/FateOperation.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/FateOperation.java
index f65f552..c726469 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/FateOperation.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/FateOperation.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum FateOperation implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum FateOperation implements org.apache.thrift.TEnum {
   TABLE_CREATE(0),
   TABLE_CLONE(1),
   TABLE_DELETE(2),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/FateService.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/FateService.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/FateService.java
index 6b337b4..4322808 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/FateService.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/FateService.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class FateService {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class FateService {
 
   public interface Iface {
 
@@ -784,7 +784,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.security.thrift.TCredentials credentials; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       CREDENTIALS((short)1, "credentials");
 
@@ -1248,7 +1248,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -1718,7 +1718,7 @@ import org.slf4j.LoggerFactory;
     public boolean autoClean; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)7, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       OPID((short)2, "opid"),
@@ -2777,7 +2777,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
 
@@ -3237,7 +3237,7 @@ import org.slf4j.LoggerFactory;
     public long opid; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       OPID((short)2, "opid");
@@ -3799,7 +3799,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
@@ -4357,7 +4357,7 @@ import org.slf4j.LoggerFactory;
     public long opid; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       OPID((short)2, "opid");
@@ -4915,7 +4915,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterClientService.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterClientService.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterClientService.java
index 0800aa9..4f4daea 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterClientService.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterClientService.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class MasterClientService {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class MasterClientService {
 
   public interface Iface extends FateService.Iface {
 
@@ -2270,7 +2270,7 @@ import org.slf4j.LoggerFactory;
     public String tableName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       TABLE_NAME((short)2, "tableName");
@@ -2834,7 +2834,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
@@ -3400,7 +3400,7 @@ import org.slf4j.LoggerFactory;
     public long maxLoops; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)5, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       TABLE_NAME((short)2, "tableName"),
@@ -4368,7 +4368,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
 
@@ -4832,7 +4832,7 @@ import org.slf4j.LoggerFactory;
     public String value; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)5, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       TABLE_NAME((short)2, "tableName"),
@@ -5590,7 +5590,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
 
@@ -6052,7 +6052,7 @@ import org.slf4j.LoggerFactory;
     public String property; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)4, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       TABLE_NAME((short)2, "tableName"),
@@ -6712,7 +6712,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
 
@@ -7176,7 +7176,7 @@ import org.slf4j.LoggerFactory;
     public String value; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)5, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       NS((short)2, "ns"),
@@ -7934,7 +7934,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
 
@@ -8396,7 +8396,7 @@ import org.slf4j.LoggerFactory;
     public String property; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)4, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       NS((short)2, "ns"),
@@ -9056,7 +9056,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
 
@@ -9520,7 +9520,7 @@ import org.slf4j.LoggerFactory;
     public MasterGoalState state; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       /**
@@ -10092,7 +10092,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -10452,7 +10452,7 @@ import org.slf4j.LoggerFactory;
     public boolean stopTabletServers; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       STOP_TABLET_SERVERS((short)2, "stopTabletServers");
@@ -11010,7 +11010,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -11372,7 +11372,7 @@ import org.slf4j.LoggerFactory;
     public boolean force; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       TABLET_SERVER((short)2, "tabletServer"),
@@ -12028,7 +12028,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -12390,7 +12390,7 @@ import org.slf4j.LoggerFactory;
     public String value; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)4, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       PROPERTY((short)2, "property"),
@@ -13048,7 +13048,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -13408,7 +13408,7 @@ import org.slf4j.LoggerFactory;
     public String property; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       PROPERTY((short)2, "property");
@@ -13968,7 +13968,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -14326,7 +14326,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.security.thrift.TCredentials credentials; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       CREDENTIALS((short)1, "credentials");
 
@@ -14790,7 +14790,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -15255,7 +15255,7 @@ import org.slf4j.LoggerFactory;
     public TabletSplit split; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)4, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       SERVER_NAME((short)2, "serverName"),
@@ -15930,7 +15930,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.data.thrift.TKeyExtent tablet; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)5, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       SERVER_NAME((short)2, "serverName"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterGoalState.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterGoalState.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterGoalState.java
index 0cf5f15..f436454 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterGoalState.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterGoalState.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum MasterGoalState implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum MasterGoalState implements org.apache.thrift.TEnum {
   CLEAN_STOP(0),
   SAFE_MODE(1),
   NORMAL(2);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterMonitorInfo.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterMonitorInfo.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterMonitorInfo.java
index bd37d3e..990fc89 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterMonitorInfo.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterMonitorInfo.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class MasterMonitorInfo implements org.apache.thrift.TBase<MasterMonitorInfo, MasterMonitorInfo._Fields>, java.io.Serializable, Cloneable, Comparable<MasterMonitorInfo> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class MasterMonitorInfo implements org.apache.thrift.TBase<MasterMonitorInfo, MasterMonitorInfo._Fields>, java.io.Serializable, Cloneable, Comparable<MasterMonitorInfo> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("MasterMonitorInfo");
 
   private static final org.apache.thrift.protocol.TField TABLE_MAP_FIELD_DESC = new org.apache.thrift.protocol.TField("tableMap", org.apache.thrift.protocol.TType.MAP, (short)1);
@@ -84,7 +84,7 @@ import org.slf4j.LoggerFactory;
   public List<DeadServer> deadTabletServers; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     TABLE_MAP((short)1, "tableMap"),
     T_SERVER_INFO((short)2, "tServerInfo"),
     BAD_TSERVERS((short)3, "badTServers"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterState.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterState.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterState.java
index f479fb5..1d63305 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterState.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterState.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum MasterState implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum MasterState implements org.apache.thrift.TEnum {
   INITIAL(0),
   HAVE_LOCK(1),
   SAFE_MODE(2),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/RecoveryException.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/RecoveryException.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/RecoveryException.java
index afb7422..025cced 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/RecoveryException.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/RecoveryException.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class RecoveryException extends TException implements org.apache.thrift.TBase<RecoveryException, RecoveryException._Fields>, java.io.Serializable, Cloneable, Comparable<RecoveryException> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class RecoveryException extends TException implements org.apache.thrift.TBase<RecoveryException, RecoveryException._Fields>, java.io.Serializable, Cloneable, Comparable<RecoveryException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("RecoveryException");
 
   private static final org.apache.thrift.protocol.TField WHY_FIELD_DESC = new org.apache.thrift.protocol.TField("why", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public String why; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     WHY((short)1, "why");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/RecoveryStatus.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/RecoveryStatus.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/RecoveryStatus.java
index 0d14d31..3ffcb03 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/RecoveryStatus.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/RecoveryStatus.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class RecoveryStatus implements org.apache.thrift.TBase<RecoveryStatus, RecoveryStatus._Fields>, java.io.Serializable, Cloneable, Comparable<RecoveryStatus> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class RecoveryStatus implements org.apache.thrift.TBase<RecoveryStatus, RecoveryStatus._Fields>, java.io.Serializable, Cloneable, Comparable<RecoveryStatus> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("RecoveryStatus");
 
   private static final org.apache.thrift.protocol.TField NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("name", org.apache.thrift.protocol.TType.STRING, (short)2);
@@ -66,7 +66,7 @@ import org.slf4j.LoggerFactory;
   public double progress; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     NAME((short)2, "name"),
     RUNTIME((short)5, "runtime"),
     PROGRESS((short)6, "progress");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/TableInfo.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/TableInfo.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/TableInfo.java
index a40df23..3c919cd 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/TableInfo.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/TableInfo.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TableInfo implements org.apache.thrift.TBase<TableInfo, TableInfo._Fields>, java.io.Serializable, Cloneable, Comparable<TableInfo> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TableInfo implements org.apache.thrift.TBase<TableInfo, TableInfo._Fields>, java.io.Serializable, Cloneable, Comparable<TableInfo> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TableInfo");
 
   private static final org.apache.thrift.protocol.TField RECS_FIELD_DESC = new org.apache.thrift.protocol.TField("recs", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -84,7 +84,7 @@ import org.slf4j.LoggerFactory;
   public double scanRate; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     RECS((short)1, "recs"),
     RECS_IN_MEMORY((short)2, "recsInMemory"),
     TABLETS((short)3, "tablets"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletLoadState.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletLoadState.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletLoadState.java
index f951c72..97338cc 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletLoadState.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletLoadState.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum TabletLoadState implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum TabletLoadState implements org.apache.thrift.TEnum {
   LOADED(0),
   LOAD_FAILURE(1),
   UNLOADED(2),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletServerStatus.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletServerStatus.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletServerStatus.java
index 6348537..1f709fb 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletServerStatus.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletServerStatus.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TabletServerStatus implements org.apache.thrift.TBase<TabletServerStatus, TabletServerStatus._Fields>, java.io.Serializable, Cloneable, Comparable<TabletServerStatus> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TabletServerStatus implements org.apache.thrift.TBase<TabletServerStatus, TabletServerStatus._Fields>, java.io.Serializable, Cloneable, Comparable<TabletServerStatus> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TabletServerStatus");
 
   private static final org.apache.thrift.protocol.TField TABLE_MAP_FIELD_DESC = new org.apache.thrift.protocol.TField("tableMap", org.apache.thrift.protocol.TType.MAP, (short)1);
@@ -82,7 +82,7 @@ import org.slf4j.LoggerFactory;
   public List<RecoveryStatus> logSorts; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     TABLE_MAP((short)1, "tableMap"),
     LAST_CONTACT((short)2, "lastContact"),
     NAME((short)3, "name"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletSplit.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletSplit.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletSplit.java
index 2eb671c..bd529b9 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletSplit.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletSplit.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TabletSplit implements org.apache.thrift.TBase<TabletSplit, TabletSplit._Fields>, java.io.Serializable, Cloneable, Comparable<TabletSplit> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TabletSplit implements org.apache.thrift.TBase<TabletSplit, TabletSplit._Fields>, java.io.Serializable, Cloneable, Comparable<TabletSplit> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TabletSplit");
 
   private static final org.apache.thrift.protocol.TField OLD_TABLET_FIELD_DESC = new org.apache.thrift.protocol.TField("oldTablet", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -64,7 +64,7 @@ import org.slf4j.LoggerFactory;
   public List<org.apache.accumulo.core.data.thrift.TKeyExtent> newTablets; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     OLD_TABLET((short)1, "oldTablet"),
     NEW_TABLETS((short)2, "newTablets");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/security/thrift/TCredentials.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/security/thrift/TCredentials.java b/core/src/main/java/org/apache/accumulo/core/security/thrift/TCredentials.java
index 8d3a3e2..0bbd241 100644
--- a/core/src/main/java/org/apache/accumulo/core/security/thrift/TCredentials.java
+++ b/core/src/main/java/org/apache/accumulo/core/security/thrift/TCredentials.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TCredentials implements org.apache.thrift.TBase<TCredentials, TCredentials._Fields>, java.io.Serializable, Cloneable, Comparable<TCredentials> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TCredentials implements org.apache.thrift.TBase<TCredentials, TCredentials._Fields>, java.io.Serializable, Cloneable, Comparable<TCredentials> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TCredentials");
 
   private static final org.apache.thrift.protocol.TField PRINCIPAL_FIELD_DESC = new org.apache.thrift.protocol.TField("principal", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -68,7 +68,7 @@ import org.slf4j.LoggerFactory;
   public String instanceId; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     PRINCIPAL((short)1, "principal"),
     TOKEN_CLASS_NAME((short)2, "tokenClassName"),
     TOKEN((short)3, "token"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActionStats.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActionStats.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActionStats.java
index 0cb5c08..86a502b 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActionStats.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActionStats.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ActionStats implements org.apache.thrift.TBase<ActionStats, ActionStats._Fields>, java.io.Serializable, Cloneable, Comparable<ActionStats> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ActionStats implements org.apache.thrift.TBase<ActionStats, ActionStats._Fields>, java.io.Serializable, Cloneable, Comparable<ActionStats> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ActionStats");
 
   private static final org.apache.thrift.protocol.TField STATUS_FIELD_DESC = new org.apache.thrift.protocol.TField("status", org.apache.thrift.protocol.TType.I32, (short)1);
@@ -76,7 +76,7 @@ import org.slf4j.LoggerFactory;
   public double queueSumDev; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     STATUS((short)1, "status"),
     ELAPSED((short)2, "elapsed"),
     NUM((short)3, "num"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActiveCompaction.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActiveCompaction.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActiveCompaction.java
index c2eddd1..9c1977d 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActiveCompaction.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActiveCompaction.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ActiveCompaction implements org.apache.thrift.TBase<ActiveCompaction, ActiveCompaction._Fields>, java.io.Serializable, Cloneable, Comparable<ActiveCompaction> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ActiveCompaction implements org.apache.thrift.TBase<ActiveCompaction, ActiveCompaction._Fields>, java.io.Serializable, Cloneable, Comparable<ActiveCompaction> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ActiveCompaction");
 
   private static final org.apache.thrift.protocol.TField EXTENT_FIELD_DESC = new org.apache.thrift.protocol.TField("extent", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -90,7 +90,7 @@ import org.slf4j.LoggerFactory;
   public Map<String,Map<String,String>> ssio; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     EXTENT((short)1, "extent"),
     AGE((short)2, "age"),
     INPUT_FILES((short)3, "inputFiles"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActiveScan.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActiveScan.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActiveScan.java
index 5371fd8..fe389e4 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActiveScan.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActiveScan.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ActiveScan implements org.apache.thrift.TBase<ActiveScan, ActiveScan._Fields>, java.io.Serializable, Cloneable, Comparable<ActiveScan> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ActiveScan implements org.apache.thrift.TBase<ActiveScan, ActiveScan._Fields>, java.io.Serializable, Cloneable, Comparable<ActiveScan> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ActiveScan");
 
   private static final org.apache.thrift.protocol.TField CLIENT_FIELD_DESC = new org.apache.thrift.protocol.TField("client", org.apache.thrift.protocol.TType.STRING, (short)2);
@@ -94,7 +94,7 @@ import org.slf4j.LoggerFactory;
   public long scanId; // optional
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     CLIENT((short)2, "client"),
     USER((short)3, "user"),
     TABLE_ID((short)4, "tableId"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/CompactionReason.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/CompactionReason.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/CompactionReason.java
index 36cce96..591dffd 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/CompactionReason.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/CompactionReason.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum CompactionReason implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum CompactionReason implements org.apache.thrift.TEnum {
   USER(0),
   SYSTEM(1),
   CHOP(2),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/CompactionType.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/CompactionType.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/CompactionType.java
index b4fdf68..f2f2cd6 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/CompactionType.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/CompactionType.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum CompactionType implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum CompactionType implements org.apache.thrift.TEnum {
   MINOR(0),
   MERGE(1),
   MAJOR(2),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ConstraintViolationException.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ConstraintViolationException.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ConstraintViolationException.java
index 9515903..7a94159 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ConstraintViolationException.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ConstraintViolationException.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ConstraintViolationException extends TException implements org.apache.thrift.TBase<ConstraintViolationException, ConstraintViolationException._Fields>, java.io.Serializable, Cloneable, Comparable<ConstraintViolationException> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ConstraintViolationException extends TException implements org.apache.thrift.TBase<ConstraintViolationException, ConstraintViolationException._Fields>, java.io.Serializable, Cloneable, Comparable<ConstraintViolationException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ConstraintViolationException");
 
   private static final org.apache.thrift.protocol.TField VIOLATION_SUMMARIES_FIELD_DESC = new org.apache.thrift.protocol.TField("violationSummaries", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public List<org.apache.accumulo.core.data.thrift.TConstraintViolationSummary> violationSummaries; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     VIOLATION_SUMMARIES((short)1, "violationSummaries");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/IteratorConfig.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/IteratorConfig.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/IteratorConfig.java
index 1a05071..9db0608 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/IteratorConfig.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/IteratorConfig.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class IteratorConfig implements org.apache.thrift.TBase<IteratorConfig, IteratorConfig._Fields>, java.io.Serializable, Cloneable, Comparable<IteratorConfig> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class IteratorConfig implements org.apache.thrift.TBase<IteratorConfig, IteratorConfig._Fields>, java.io.Serializable, Cloneable, Comparable<IteratorConfig> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("IteratorConfig");
 
   private static final org.apache.thrift.protocol.TField ITERATORS_FIELD_DESC = new org.apache.thrift.protocol.TField("iterators", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public List<TIteratorSetting> iterators; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     ITERATORS((short)1, "iterators");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/NoSuchScanIDException.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/NoSuchScanIDException.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/NoSuchScanIDException.java
index 79f664f..c0dc02b 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/NoSuchScanIDException.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/NoSuchScanIDException.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class NoSuchScanIDException extends TException implements org.apache.thrift.TBase<NoSuchScanIDException, NoSuchScanIDException._Fields>, java.io.Serializable, Cloneable, Comparable<NoSuchScanIDException> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class NoSuchScanIDException extends TException implements org.apache.thrift.TBase<NoSuchScanIDException, NoSuchScanIDException._Fields>, java.io.Serializable, Cloneable, Comparable<NoSuchScanIDException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("NoSuchScanIDException");
 
 
@@ -60,7 +60,7 @@ import org.slf4j.LoggerFactory;
 
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
 ;
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/NotServingTabletException.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/NotServingTabletException.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/NotServingTabletException.java
index c43b5c0..ef87937 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/NotServingTabletException.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/NotServingTabletException.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class NotServingTabletException extends TException implements org.apache.thrift.TBase<NotServingTabletException, NotServingTabletException._Fields>, java.io.Serializable, Cloneable, Comparable<NotServingTabletException> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class NotServingTabletException extends TException implements org.apache.thrift.TBase<NotServingTabletException, NotServingTabletException._Fields>, java.io.Serializable, Cloneable, Comparable<NotServingTabletException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("NotServingTabletException");
 
   private static final org.apache.thrift.protocol.TField EXTENT_FIELD_DESC = new org.apache.thrift.protocol.TField("extent", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public org.apache.accumulo.core.data.thrift.TKeyExtent extent; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     EXTENT((short)1, "extent");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ScanState.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ScanState.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ScanState.java
index c676599..5bb6857 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ScanState.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ScanState.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum ScanState implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum ScanState implements org.apache.thrift.TEnum {
   IDLE(0),
   RUNNING(1),
   QUEUED(2);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ScanType.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ScanType.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ScanType.java
index cb333a5..34d7ac5 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ScanType.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ScanType.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum ScanType implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum ScanType implements org.apache.thrift.TEnum {
   SINGLE(0),
   BATCH(1);
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TIteratorSetting.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TIteratorSetting.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TIteratorSetting.java
index f457311..8eddaba 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TIteratorSetting.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TIteratorSetting.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TIteratorSetting implements org.apache.thrift.TBase<TIteratorSetting, TIteratorSetting._Fields>, java.io.Serializable, Cloneable, Comparable<TIteratorSetting> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TIteratorSetting implements org.apache.thrift.TBase<TIteratorSetting, TIteratorSetting._Fields>, java.io.Serializable, Cloneable, Comparable<TIteratorSetting> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TIteratorSetting");
 
   private static final org.apache.thrift.protocol.TField PRIORITY_FIELD_DESC = new org.apache.thrift.protocol.TField("priority", org.apache.thrift.protocol.TType.I32, (short)1);
@@ -68,7 +68,7 @@ import org.slf4j.LoggerFactory;
   public Map<String,String> properties; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     PRIORITY((short)1, "priority"),
     NAME((short)2, "name"),
     ITERATOR_CLASS((short)3, "iteratorClass"),


[04/25] accumulo git commit: ACCUMULO-3759 More Java 8 compiler warnings

Posted by ct...@apache.org.
ACCUMULO-3759 More Java 8 compiler warnings

* Fix compiler warnings in Java 8 for 1.5 branch


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

Branch: refs/heads/1.7
Commit: e395bc8ced5d740fe4a6e5d3ebb169335f64c044
Parents: 5ac1b52
Author: Christopher Tubbs <ct...@apache.org>
Authored: Thu Apr 30 12:04:50 2015 -0400
Committer: Christopher Tubbs <ct...@apache.org>
Committed: Thu Apr 30 12:04:50 2015 -0400

----------------------------------------------------------------------
 .../core/iterators/AggregatingIterator.java       | 18 ++++++++++--------
 .../aggregation/conf/AggregatorConfiguration.java |  3 +--
 .../iterators/aggregation/conf/AggregatorSet.java |  7 +++----
 .../util/shell/commands/AddSplitsCommand.java     | 18 +++++++++++++-----
 .../core/iterators/AggregatingIteratorTest.java   |  6 ++++--
 .../conf/AggregatorConfigurationTest.java         | 13 ++++++++-----
 .../org/apache/accumulo/server/master/Master.java | 16 ++++++++--------
 .../classloader/vfs/AccumuloVFSClassLoader.java   |  6 +++---
 8 files changed, 50 insertions(+), 37 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/e395bc8c/core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java b/core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java
index 28acc2b..13b2710 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java
@@ -27,7 +27,6 @@ import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.data.PartialKey;
 import org.apache.accumulo.core.data.Range;
 import org.apache.accumulo.core.data.Value;
-import org.apache.accumulo.core.iterators.aggregation.Aggregator;
 import org.apache.accumulo.core.iterators.conf.ColumnToClassMapping;
 import org.apache.accumulo.start.classloader.vfs.AccumuloVFSClassLoader;
 import org.apache.log4j.Logger;
@@ -42,7 +41,7 @@ import org.apache.log4j.Logger;
 public class AggregatingIterator implements SortedKeyValueIterator<Key,Value>, OptionDescriber {
 
   private SortedKeyValueIterator<Key,Value> iterator;
-  private ColumnToClassMapping<Aggregator> aggregators;
+  private ColumnToClassMapping<org.apache.accumulo.core.iterators.aggregation.Aggregator> aggregators;
 
   private Key workKey = new Key();
 
@@ -51,6 +50,7 @@ public class AggregatingIterator implements SortedKeyValueIterator<Key,Value>, O
   // private boolean propogateDeletes;
   private static final Logger log = Logger.getLogger(AggregatingIterator.class);
 
+  @Override
   public AggregatingIterator deepCopy(IteratorEnvironment env) {
     return new AggregatingIterator(this, env);
   }
@@ -62,7 +62,7 @@ public class AggregatingIterator implements SortedKeyValueIterator<Key,Value>, O
 
   public AggregatingIterator() {}
 
-  private void aggregateRowColumn(Aggregator aggr) throws IOException {
+  private void aggregateRowColumn(org.apache.accumulo.core.iterators.aggregation.Aggregator aggr) throws IOException {
     // this function assumes that first value is not delete
 
     if (iterator.getTopKey().isDeleted())
@@ -90,14 +90,15 @@ public class AggregatingIterator implements SortedKeyValueIterator<Key,Value>, O
   private void findTop() throws IOException {
     // check if aggregation is needed
     if (iterator.hasTop()) {
-      Aggregator aggr = aggregators.getObject(iterator.getTopKey());
+      org.apache.accumulo.core.iterators.aggregation.Aggregator aggr = aggregators.getObject(iterator.getTopKey());
       if (aggr != null) {
         aggregateRowColumn(aggr);
       }
     }
   }
 
-  public AggregatingIterator(SortedKeyValueIterator<Key,Value> iterator, ColumnToClassMapping<Aggregator> aggregators) throws IOException {
+  public AggregatingIterator(SortedKeyValueIterator<Key,Value> iterator,
+      ColumnToClassMapping<org.apache.accumulo.core.iterators.aggregation.Aggregator> aggregators) throws IOException {
     this.iterator = iterator;
     this.aggregators = aggregators;
   }
@@ -167,7 +168,8 @@ public class AggregatingIterator implements SortedKeyValueIterator<Key,Value>, O
     this.iterator = source;
 
     try {
-      this.aggregators = new ColumnToClassMapping<Aggregator>(options, Aggregator.class);
+      this.aggregators = new ColumnToClassMapping<org.apache.accumulo.core.iterators.aggregation.Aggregator>(options,
+          org.apache.accumulo.core.iterators.aggregation.Aggregator.class);
     } catch (ClassNotFoundException e) {
       log.error(e.toString());
       throw new IllegalArgumentException(e);
@@ -192,9 +194,9 @@ public class AggregatingIterator implements SortedKeyValueIterator<Key,Value>, O
       String classname = entry.getValue();
       if (classname == null)
         throw new IllegalArgumentException("classname null");
-      Class<? extends Aggregator> clazz;
+      Class<? extends org.apache.accumulo.core.iterators.aggregation.Aggregator> clazz;
       try {
-        clazz = AccumuloVFSClassLoader.loadClass(classname, Aggregator.class);
+        clazz = AccumuloVFSClassLoader.loadClass(classname, org.apache.accumulo.core.iterators.aggregation.Aggregator.class);
         clazz.newInstance();
       } catch (ClassNotFoundException e) {
         throw new IllegalArgumentException("class not found: " + classname);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/e395bc8c/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfiguration.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfiguration.java b/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfiguration.java
index 41c0374..3432cf5 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfiguration.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfiguration.java
@@ -16,14 +16,13 @@
  */
 package org.apache.accumulo.core.iterators.aggregation.conf;
 
-import org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig;
 import org.apache.hadoop.io.Text;
 
 /**
  * @deprecated since 1.4
  */
 @Deprecated
-public class AggregatorConfiguration extends PerColumnIteratorConfig {
+public class AggregatorConfiguration extends org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig {
 
   public AggregatorConfiguration(Text columnFamily, String aggClassName) {
     super(columnFamily, aggClassName);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/e395bc8c/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorSet.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorSet.java b/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorSet.java
index 26e2f11..37798b0 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorSet.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorSet.java
@@ -19,23 +19,22 @@ package org.apache.accumulo.core.iterators.aggregation.conf;
 import java.util.Map;
 
 import org.apache.accumulo.core.data.Key;
-import org.apache.accumulo.core.iterators.aggregation.Aggregator;
 import org.apache.accumulo.core.iterators.conf.ColumnToClassMapping;
 
 /**
  * @deprecated since 1.4
  */
 @Deprecated
-public class AggregatorSet extends ColumnToClassMapping<Aggregator> {
+public class AggregatorSet extends ColumnToClassMapping<org.apache.accumulo.core.iterators.aggregation.Aggregator> {
   public AggregatorSet(Map<String,String> opts) throws InstantiationException, IllegalAccessException, ClassNotFoundException {
-    super(opts, Aggregator.class);
+    super(opts, org.apache.accumulo.core.iterators.aggregation.Aggregator.class);
   }
 
   public AggregatorSet() {
     super();
   }
 
-  public Aggregator getAggregator(Key k) {
+  public org.apache.accumulo.core.iterators.aggregation.Aggregator getAggregator(Key k) {
     return getObject(k);
   }
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/e395bc8c/core/src/main/java/org/apache/accumulo/core/util/shell/commands/AddSplitsCommand.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/util/shell/commands/AddSplitsCommand.java b/core/src/main/java/org/apache/accumulo/core/util/shell/commands/AddSplitsCommand.java
index 3eab0a1..c88171a 100644
--- a/core/src/main/java/org/apache/accumulo/core/util/shell/commands/AddSplitsCommand.java
+++ b/core/src/main/java/org/apache/accumulo/core/util/shell/commands/AddSplitsCommand.java
@@ -34,6 +34,7 @@ import org.apache.hadoop.io.Text;
 public class AddSplitsCommand extends Command {
   private Option optSplitsFile, base64Opt;
 
+  @Override
   public int execute(final String fullCommand, final CommandLine cl, final Shell shellState) throws Exception {
     final String tableName = OptUtil.getTableOpt(cl, shellState);
     final boolean decode = cl.hasOption(base64Opt.getOpt());
@@ -44,11 +45,18 @@ public class AddSplitsCommand extends Command {
       final String f = cl.getOptionValue(optSplitsFile.getOpt());
 
       String line;
-      java.util.Scanner file = new java.util.Scanner(new File(f), UTF_8.name());
-      while (file.hasNextLine()) {
-        line = file.nextLine();
-        if (!line.isEmpty()) {
-          splits.add(decode ? new Text(Base64.decodeBase64(line.getBytes(UTF_8))) : new Text(line));
+      java.util.Scanner file = null;
+      try {
+        file = new java.util.Scanner(new File(f), UTF_8.name());
+        while (file.hasNextLine()) {
+          line = file.nextLine();
+          if (!line.isEmpty()) {
+            splits.add(decode ? new Text(Base64.decodeBase64(line.getBytes(UTF_8))) : new Text(line));
+          }
+        }
+      } finally {
+        if (file != null) {
+          file.close();
         }
       }
     } else {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/e395bc8c/core/src/test/java/org/apache/accumulo/core/iterators/AggregatingIteratorTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/iterators/AggregatingIteratorTest.java b/core/src/test/java/org/apache/accumulo/core/iterators/AggregatingIteratorTest.java
index 788366a..f1918b4 100644
--- a/core/src/test/java/org/apache/accumulo/core/iterators/AggregatingIteratorTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/iterators/AggregatingIteratorTest.java
@@ -31,7 +31,6 @@ import org.apache.accumulo.core.data.ByteSequence;
 import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.data.Range;
 import org.apache.accumulo.core.data.Value;
-import org.apache.accumulo.core.iterators.aggregation.Aggregator;
 import org.apache.accumulo.core.iterators.system.MultiIterator;
 import org.apache.hadoop.io.Text;
 
@@ -43,20 +42,23 @@ public class AggregatingIteratorTest extends TestCase {
 
   private static final Collection<ByteSequence> EMPTY_COL_FAMS = new ArrayList<ByteSequence>();
 
-  public static class SummationAggregator implements Aggregator {
+  public static class SummationAggregator implements org.apache.accumulo.core.iterators.aggregation.Aggregator {
 
     int sum;
 
+    @Override
     public Value aggregate() {
       return new Value((sum + "").getBytes());
     }
 
+    @Override
     public void collect(Value value) {
       int val = Integer.parseInt(value.toString());
 
       sum += val;
     }
 
+    @Override
     public void reset() {
       sum = 0;
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/e395bc8c/core/src/test/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfigurationTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfigurationTest.java b/core/src/test/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfigurationTest.java
index 1a285bc..6d666a3 100644
--- a/core/src/test/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfigurationTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfigurationTest.java
@@ -18,7 +18,6 @@ package org.apache.accumulo.core.iterators.aggregation.conf;
 
 import junit.framework.TestCase;
 
-import org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig;
 import org.apache.hadoop.io.Text;
 
 /**
@@ -46,18 +45,22 @@ public class AggregatorConfigurationTest extends TestCase {
 
   private void runTest(Text colf) {
     String encodedCols;
-    PerColumnIteratorConfig ac3 = new PerColumnIteratorConfig(colf, "com.foo.SuperAgg");
+    org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig ac3 = new org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig(colf,
+        "com.foo.SuperAgg");
     encodedCols = ac3.encodeColumns();
-    PerColumnIteratorConfig ac4 = PerColumnIteratorConfig.decodeColumns(encodedCols, "com.foo.SuperAgg");
+    org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig ac4 = org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig.decodeColumns(
+        encodedCols, "com.foo.SuperAgg");
 
     assertEquals(colf, ac4.getColumnFamily());
     assertNull(ac4.getColumnQualifier());
   }
 
   private void runTest(Text colf, Text colq) {
-    PerColumnIteratorConfig ac = new PerColumnIteratorConfig(colf, colq, "com.foo.SuperAgg");
+    org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig ac = new org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig(colf, colq,
+        "com.foo.SuperAgg");
     String encodedCols = ac.encodeColumns();
-    PerColumnIteratorConfig ac2 = PerColumnIteratorConfig.decodeColumns(encodedCols, "com.foo.SuperAgg");
+    org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig ac2 = org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig.decodeColumns(
+        encodedCols, "com.foo.SuperAgg");
 
     assertEquals(colf, ac2.getColumnFamily());
     assertEquals(colq, ac2.getColumnQualifier());

http://git-wip-us.apache.org/repos/asf/accumulo/blob/e395bc8c/server/src/main/java/org/apache/accumulo/server/master/Master.java
----------------------------------------------------------------------
diff --git a/server/src/main/java/org/apache/accumulo/server/master/Master.java b/server/src/main/java/org/apache/accumulo/server/master/Master.java
index 61ba7cf..dd94683 100644
--- a/server/src/main/java/org/apache/accumulo/server/master/Master.java
+++ b/server/src/main/java/org/apache/accumulo/server/master/Master.java
@@ -230,17 +230,17 @@ public class Master implements LiveTServerSet.Listener, TableObserver, CurrentSt
   }
 
   static final boolean X = true;
-  static final boolean _ = false;
+  static final boolean O = false;
   // @formatter:off
   static final boolean transitionOK[][] = {
       //                              INITIAL HAVE_LOCK SAFE_MODE NORMAL UNLOAD_META UNLOAD_ROOT STOP
-      /* INITIAL */                   {X,     X,        _,        _,      _,         _,          X},
-      /* HAVE_LOCK */                 {_,     X,        X,        X,      _,         _,          X},
-      /* SAFE_MODE */                 {_,     _,        X,        X,      X,         _,          X},
-      /* NORMAL */                    {_,     _,        X,        X,      X,         _,          X},
-      /* UNLOAD_METADATA_TABLETS */   {_,     _,        X,        X,      X,         X,          X},
-      /* UNLOAD_ROOT_TABLET */        {_,     _,        _,        X,      _,         X,          X},
-      /* STOP */                      {_,     _,        _,        _,      _,         _,          X}};
+      /* INITIAL */                   {X,     X,        O,        O,      O,         O,          X},
+      /* HAVE_LOCK */                 {O,     X,        X,        X,      O,         O,          X},
+      /* SAFE_MODE */                 {O,     O,        X,        X,      X,         O,          X},
+      /* NORMAL */                    {O,     O,        X,        X,      X,         O,          X},
+      /* UNLOAD_METADATA_TABLETS */   {O,     O,        X,        X,      X,         X,          X},
+      /* UNLOAD_ROOT_TABLET */        {O,     O,        O,        X,      O,         X,          X},
+      /* STOP */                      {O,     O,        O,        O,      O,         O,          X}};
   //@formatter:on
   synchronized private void setMasterState(MasterState newState) {
     if (state.equals(newState))

http://git-wip-us.apache.org/repos/asf/accumulo/blob/e395bc8c/start/src/main/java/org/apache/accumulo/start/classloader/vfs/AccumuloVFSClassLoader.java
----------------------------------------------------------------------
diff --git a/start/src/main/java/org/apache/accumulo/start/classloader/vfs/AccumuloVFSClassLoader.java b/start/src/main/java/org/apache/accumulo/start/classloader/vfs/AccumuloVFSClassLoader.java
index 7fa17d6..0abc79a 100644
--- a/start/src/main/java/org/apache/accumulo/start/classloader/vfs/AccumuloVFSClassLoader.java
+++ b/start/src/main/java/org/apache/accumulo/start/classloader/vfs/AccumuloVFSClassLoader.java
@@ -62,6 +62,7 @@ public class AccumuloVFSClassLoader {
 
   public static class AccumuloVFSClassLoaderShutdownThread implements Runnable {
 
+    @Override
     public void run() {
       try {
         AccumuloVFSClassLoader.close();
@@ -100,7 +101,7 @@ public class AccumuloVFSClassLoader {
 
   public synchronized static <U> Class<? extends U> loadClass(String classname, Class<U> extension) throws ClassNotFoundException {
     try {
-      return (Class<? extends U>) getClassLoader().loadClass(classname).asSubclass(extension);
+      return getClassLoader().loadClass(classname).asSubclass(extension);
     } catch (IOException e) {
       throw new ClassNotFoundException("IO Error loading class " + classname, e);
     }
@@ -326,10 +327,9 @@ public class AccumuloVFSClassLoader {
 
         if (classLoader instanceof URLClassLoader) {
           // If VFS class loader enabled, but no contexts defined.
-          URLClassLoader ucl = (URLClassLoader) classLoader;
           out.print("Level " + classLoaderDescription + " URL classpath items are:");
 
-          for (URL u : ucl.getURLs()) {
+          for (URL u : ((URLClassLoader) classLoader).getURLs()) {
             out.print("\t" + u.toExternalForm());
           }
 


[22/25] accumulo git commit: ACCUMULO-3759 More build warnings on Java 8

Posted by ct...@apache.org.
ACCUMULO-3759 More build warnings on Java 8

* Clean up build output while generating example configs
* Fix javac warnings from thrift
* Enable specifying different findbugs version to build on jdk8


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

Branch: refs/heads/1.6
Commit: bbcc6da446b737507dfd9c486b5673055fbdf0ab
Parents: b636ff2
Author: Christopher Tubbs <ct...@apache.org>
Authored: Thu Apr 30 13:00:18 2015 -0400
Committer: Christopher Tubbs <ct...@apache.org>
Committed: Thu Apr 30 13:29:30 2015 -0400

----------------------------------------------------------------------
 .../main/scripts/generate-example-configs.sh    |   7 +-
 .../core/client/impl/thrift/ClientService.java  | 122 ++++----
 .../client/impl/thrift/ConfigurationType.java   |   2 +-
 .../client/impl/thrift/SecurityErrorCode.java   |   2 +-
 .../core/client/impl/thrift/TDiskUsage.java     |   4 +-
 .../core/client/impl/thrift/TableOperation.java |   2 +-
 .../thrift/TableOperationExceptionType.java     |   2 +-
 .../impl/thrift/ThriftSecurityException.java    |   4 +-
 .../thrift/ThriftTableOperationException.java   |   4 +-
 .../core/client/impl/thrift/ThriftTest.java     |  14 +-
 .../lib/impl/DistributedCacheHelper.java        |   7 +-
 .../core/data/thrift/InitialMultiScan.java      |   4 +-
 .../accumulo/core/data/thrift/InitialScan.java  |   4 +-
 .../accumulo/core/data/thrift/IterInfo.java     |   4 +-
 .../accumulo/core/data/thrift/MapFileInfo.java  |   4 +-
 .../core/data/thrift/MultiScanResult.java       |   4 +-
 .../accumulo/core/data/thrift/ScanResult.java   |   4 +-
 .../accumulo/core/data/thrift/TCMResult.java    |   4 +-
 .../accumulo/core/data/thrift/TCMStatus.java    |   2 +-
 .../accumulo/core/data/thrift/TColumn.java      |   4 +-
 .../accumulo/core/data/thrift/TCondition.java   |   4 +-
 .../core/data/thrift/TConditionalMutation.java  |   4 +-
 .../core/data/thrift/TConditionalSession.java   |   4 +-
 .../thrift/TConstraintViolationSummary.java     |   4 +-
 .../apache/accumulo/core/data/thrift/TKey.java  |   4 +-
 .../accumulo/core/data/thrift/TKeyExtent.java   |   4 +-
 .../accumulo/core/data/thrift/TKeyValue.java    |   4 +-
 .../accumulo/core/data/thrift/TMutation.java    |   4 +-
 .../accumulo/core/data/thrift/TRange.java       |   4 +-
 .../accumulo/core/data/thrift/UpdateErrors.java |   4 +-
 .../core/gc/thrift/GCMonitorService.java        |   6 +-
 .../accumulo/core/gc/thrift/GCStatus.java       |   4 +-
 .../accumulo/core/gc/thrift/GcCycleStats.java   |   4 +-
 .../accumulo/core/master/thrift/Compacting.java |   4 +-
 .../accumulo/core/master/thrift/DeadServer.java |   4 +-
 .../core/master/thrift/FateOperation.java       |   2 +-
 .../core/master/thrift/FateService.java         |  18 +-
 .../core/master/thrift/MasterClientService.java |  54 ++--
 .../core/master/thrift/MasterGoalState.java     |   2 +-
 .../core/master/thrift/MasterMonitorInfo.java   |   4 +-
 .../core/master/thrift/MasterState.java         |   2 +-
 .../core/master/thrift/RecoveryException.java   |   4 +-
 .../core/master/thrift/RecoveryStatus.java      |   4 +-
 .../accumulo/core/master/thrift/TableInfo.java  |   4 +-
 .../core/master/thrift/TabletLoadState.java     |   2 +-
 .../core/master/thrift/TabletServerStatus.java  |   4 +-
 .../core/master/thrift/TabletSplit.java         |   4 +-
 .../core/security/thrift/TCredentials.java      |   4 +-
 .../core/tabletserver/thrift/ActionStats.java   |   4 +-
 .../tabletserver/thrift/ActiveCompaction.java   |   4 +-
 .../core/tabletserver/thrift/ActiveScan.java    |   4 +-
 .../tabletserver/thrift/CompactionReason.java   |   2 +-
 .../tabletserver/thrift/CompactionType.java     |   2 +-
 .../thrift/ConstraintViolationException.java    |   4 +-
 .../tabletserver/thrift/IteratorConfig.java     |   4 +-
 .../thrift/NoSuchScanIDException.java           |   4 +-
 .../thrift/NotServingTabletException.java       |   4 +-
 .../core/tabletserver/thrift/ScanState.java     |   2 +-
 .../core/tabletserver/thrift/ScanType.java      |   2 +-
 .../tabletserver/thrift/TIteratorSetting.java   |   4 +-
 .../thrift/TabletClientService.java             | 100 +++---
 .../core/tabletserver/thrift/TabletStats.java   |   4 +-
 .../thrift/TooManyFilesException.java           |   4 +-
 core/src/main/scripts/generate-thrift.sh        |  50 +--
 pom.xml                                         |   6 +-
 .../proxy/thrift/AccumuloException.java         |   4 +-
 .../accumulo/proxy/thrift/AccumuloProxy.java    | 308 +++++++++----------
 .../proxy/thrift/AccumuloSecurityException.java |   4 +-
 .../accumulo/proxy/thrift/ActiveCompaction.java |   4 +-
 .../accumulo/proxy/thrift/ActiveScan.java       |   4 +-
 .../accumulo/proxy/thrift/BatchScanOptions.java |   4 +-
 .../apache/accumulo/proxy/thrift/Column.java    |   4 +-
 .../accumulo/proxy/thrift/ColumnUpdate.java     |   4 +-
 .../accumulo/proxy/thrift/CompactionReason.java |   2 +-
 .../accumulo/proxy/thrift/CompactionType.java   |   2 +-
 .../apache/accumulo/proxy/thrift/Condition.java |   4 +-
 .../proxy/thrift/ConditionalStatus.java         |   2 +-
 .../proxy/thrift/ConditionalUpdates.java        |   4 +-
 .../proxy/thrift/ConditionalWriterOptions.java  |   4 +-
 .../apache/accumulo/proxy/thrift/DiskUsage.java |   4 +-
 .../accumulo/proxy/thrift/IteratorScope.java    |   2 +-
 .../accumulo/proxy/thrift/IteratorSetting.java  |   4 +-
 .../org/apache/accumulo/proxy/thrift/Key.java   |   4 +-
 .../apache/accumulo/proxy/thrift/KeyExtent.java |   4 +-
 .../apache/accumulo/proxy/thrift/KeyValue.java  |   4 +-
 .../accumulo/proxy/thrift/KeyValueAndPeek.java  |   4 +-
 .../thrift/MutationsRejectedException.java      |   4 +-
 .../proxy/thrift/NoMoreEntriesException.java    |   4 +-
 .../accumulo/proxy/thrift/PartialKey.java       |   2 +-
 .../org/apache/accumulo/proxy/thrift/Range.java |   4 +-
 .../accumulo/proxy/thrift/ScanColumn.java       |   4 +-
 .../accumulo/proxy/thrift/ScanOptions.java      |   4 +-
 .../accumulo/proxy/thrift/ScanResult.java       |   4 +-
 .../apache/accumulo/proxy/thrift/ScanState.java |   2 +-
 .../apache/accumulo/proxy/thrift/ScanType.java  |   2 +-
 .../accumulo/proxy/thrift/SystemPermission.java |   2 +-
 .../proxy/thrift/TableExistsException.java      |   4 +-
 .../proxy/thrift/TableNotFoundException.java    |   4 +-
 .../accumulo/proxy/thrift/TablePermission.java  |   2 +-
 .../apache/accumulo/proxy/thrift/TimeType.java  |   2 +-
 .../accumulo/proxy/thrift/UnknownScanner.java   |   4 +-
 .../accumulo/proxy/thrift/UnknownWriter.java    |   4 +-
 .../accumulo/proxy/thrift/WriterOptions.java    |   4 +-
 .../accumulo/trace/thrift/RemoteSpan.java       |   4 +-
 .../accumulo/trace/thrift/SpanReceiver.java     |   4 +-
 .../org/apache/accumulo/trace/thrift/TInfo.java |   4 +-
 .../accumulo/trace/thrift/TestService.java      |   6 +-
 trace/src/main/scripts/generate-thrift.sh       |   4 +
 108 files changed, 523 insertions(+), 513 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/assemble/src/main/scripts/generate-example-configs.sh
----------------------------------------------------------------------
diff --git a/assemble/src/main/scripts/generate-example-configs.sh b/assemble/src/main/scripts/generate-example-configs.sh
index 16c9f4f..9dfbfe1 100755
--- a/assemble/src/main/scripts/generate-example-configs.sh
+++ b/assemble/src/main/scripts/generate-example-configs.sh
@@ -17,9 +17,12 @@
 
 # This script will regenerate the example configuration files for the tarball
 
+out=target/bootstrap-config.out
+
+echo 'Generating example scripts...' > $out
 for s in 1GB 2GB 3GB 512MB
 do
-  bin/bootstrap_config.sh -o -d target/example-configs/$s/standalone -s $s -j -v 2
-  bin/bootstrap_config.sh -o -d target/example-configs/$s/native-standalone -s $s -n -v 2
+  bin/bootstrap_config.sh -o -d target/example-configs/$s/standalone -s $s -j -v 2 >> $out 2>&1
+  bin/bootstrap_config.sh -o -d target/example-configs/$s/native-standalone -s $s -n -v 2 >> $out 2>&1
 done
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ClientService.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ClientService.java b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ClientService.java
index 638a8b7..5dd2cd5 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ClientService.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ClientService.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ClientService {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ClientService {
 
   public interface Iface {
 
@@ -4776,7 +4776,7 @@ import org.slf4j.LoggerFactory;
 
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
 ;
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -5024,7 +5024,7 @@ import org.slf4j.LoggerFactory;
     public String success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -5376,7 +5376,7 @@ import org.slf4j.LoggerFactory;
 
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
 ;
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -5624,7 +5624,7 @@ import org.slf4j.LoggerFactory;
     public String success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -5976,7 +5976,7 @@ import org.slf4j.LoggerFactory;
 
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
 ;
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -6224,7 +6224,7 @@ import org.slf4j.LoggerFactory;
     public String success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -6590,7 +6590,7 @@ import org.slf4j.LoggerFactory;
     public boolean setTime; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)8, "credentials"),
       TID((short)3, "tid"),
@@ -7587,7 +7587,7 @@ import org.slf4j.LoggerFactory;
     public ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
@@ -8192,7 +8192,7 @@ import org.slf4j.LoggerFactory;
     public long tid; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       TID((short)2, "tid");
 
@@ -8647,7 +8647,7 @@ import org.slf4j.LoggerFactory;
     public boolean success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -9001,7 +9001,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.security.thrift.TCredentials credentials; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       CREDENTIALS((short)2, "credentials");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -9360,7 +9360,7 @@ import org.slf4j.LoggerFactory;
     public ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -9718,7 +9718,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.security.thrift.TCredentials credentials; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TABLES((short)2, "tables"),
       CREDENTIALS((short)1, "credentials");
 
@@ -10228,7 +10228,7 @@ import org.slf4j.LoggerFactory;
     public ThriftTableOperationException toe; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec"),
       TOE((short)2, "toe");
@@ -10838,7 +10838,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.security.thrift.TCredentials credentials; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       CREDENTIALS((short)3, "credentials");
 
@@ -11302,7 +11302,7 @@ import org.slf4j.LoggerFactory;
     public ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -11811,7 +11811,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer password; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)5, "tinfo"),
       CREDENTIALS((short)6, "credentials"),
       PRINCIPAL((short)2, "principal"),
@@ -12480,7 +12480,7 @@ import org.slf4j.LoggerFactory;
     public ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -12840,7 +12840,7 @@ import org.slf4j.LoggerFactory;
     public String principal; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)4, "credentials"),
       PRINCIPAL((short)2, "principal");
@@ -13400,7 +13400,7 @@ import org.slf4j.LoggerFactory;
     public ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -13762,7 +13762,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer password; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)4, "tinfo"),
       CREDENTIALS((short)5, "credentials"),
       PRINCIPAL((short)2, "principal"),
@@ -14431,7 +14431,7 @@ import org.slf4j.LoggerFactory;
     public ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -14789,7 +14789,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.security.thrift.TCredentials credentials; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)2, "credentials");
 
@@ -15253,7 +15253,7 @@ import org.slf4j.LoggerFactory;
     public ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -15711,7 +15711,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.security.thrift.TCredentials toAuth; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)2, "credentials"),
       TO_AUTH((short)3, "toAuth");
@@ -16278,7 +16278,7 @@ import org.slf4j.LoggerFactory;
     public ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -16738,7 +16738,7 @@ import org.slf4j.LoggerFactory;
     public List<ByteBuffer> authorizations; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)4, "tinfo"),
       CREDENTIALS((short)5, "credentials"),
       PRINCIPAL((short)2, "principal"),
@@ -17445,7 +17445,7 @@ import org.slf4j.LoggerFactory;
     public ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -17805,7 +17805,7 @@ import org.slf4j.LoggerFactory;
     public String principal; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)4, "credentials"),
       PRINCIPAL((short)2, "principal");
@@ -18367,7 +18367,7 @@ import org.slf4j.LoggerFactory;
     public ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -18876,7 +18876,7 @@ import org.slf4j.LoggerFactory;
     public byte sysPerm; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)4, "tinfo"),
       CREDENTIALS((short)5, "credentials"),
       PRINCIPAL((short)2, "principal"),
@@ -19534,7 +19534,7 @@ import org.slf4j.LoggerFactory;
     public ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -19996,7 +19996,7 @@ import org.slf4j.LoggerFactory;
     public byte tblPerm; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)5, "tinfo"),
       CREDENTIALS((short)6, "credentials"),
       PRINCIPAL((short)2, "principal"),
@@ -20754,7 +20754,7 @@ import org.slf4j.LoggerFactory;
     public ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
@@ -21316,7 +21316,7 @@ import org.slf4j.LoggerFactory;
     public byte tblNspcPerm; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)2, "credentials"),
       PRINCIPAL((short)3, "principal"),
@@ -22074,7 +22074,7 @@ import org.slf4j.LoggerFactory;
     public ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
@@ -22634,7 +22634,7 @@ import org.slf4j.LoggerFactory;
     public byte permission; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)4, "tinfo"),
       CREDENTIALS((short)5, "credentials"),
       PRINCIPAL((short)2, "principal"),
@@ -23290,7 +23290,7 @@ import org.slf4j.LoggerFactory;
     public ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -23652,7 +23652,7 @@ import org.slf4j.LoggerFactory;
     public byte permission; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)4, "tinfo"),
       CREDENTIALS((short)5, "credentials"),
       PRINCIPAL((short)2, "principal"),
@@ -24308,7 +24308,7 @@ import org.slf4j.LoggerFactory;
     public ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -24672,7 +24672,7 @@ import org.slf4j.LoggerFactory;
     public byte permission; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)5, "tinfo"),
       CREDENTIALS((short)6, "credentials"),
       PRINCIPAL((short)2, "principal"),
@@ -25428,7 +25428,7 @@ import org.slf4j.LoggerFactory;
     public ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
 
@@ -25892,7 +25892,7 @@ import org.slf4j.LoggerFactory;
     public byte permission; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)5, "tinfo"),
       CREDENTIALS((short)6, "credentials"),
       PRINCIPAL((short)2, "principal"),
@@ -26648,7 +26648,7 @@ import org.slf4j.LoggerFactory;
     public ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
 
@@ -27112,7 +27112,7 @@ import org.slf4j.LoggerFactory;
     public byte permission; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)2, "credentials"),
       PRINCIPAL((short)3, "principal"),
@@ -27868,7 +27868,7 @@ import org.slf4j.LoggerFactory;
     public ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
 
@@ -28332,7 +28332,7 @@ import org.slf4j.LoggerFactory;
     public byte permission; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)2, "credentials"),
       PRINCIPAL((short)3, "principal"),
@@ -29088,7 +29088,7 @@ import org.slf4j.LoggerFactory;
     public ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
 
@@ -29552,7 +29552,7 @@ import org.slf4j.LoggerFactory;
     public ConfigurationType type; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       CREDENTIALS((short)3, "credentials"),
       /**
@@ -30124,7 +30124,7 @@ import org.slf4j.LoggerFactory;
     public Map<String,String> success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -30534,7 +30534,7 @@ import org.slf4j.LoggerFactory;
     public String tableName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)3, "credentials"),
       TABLE_NAME((short)2, "tableName");
@@ -31096,7 +31096,7 @@ import org.slf4j.LoggerFactory;
     public ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       TOPE((short)1, "tope");
 
@@ -31606,7 +31606,7 @@ import org.slf4j.LoggerFactory;
     public String ns; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)2, "credentials"),
       NS((short)3, "ns");
@@ -32168,7 +32168,7 @@ import org.slf4j.LoggerFactory;
     public ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       TOPE((short)1, "tope");
 
@@ -32680,7 +32680,7 @@ import org.slf4j.LoggerFactory;
     public String interfaceMatch; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)4, "credentials"),
       CLASS_NAME((short)2, "className"),
@@ -33338,7 +33338,7 @@ import org.slf4j.LoggerFactory;
     public boolean success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -33700,7 +33700,7 @@ import org.slf4j.LoggerFactory;
     public String interfaceMatch; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)5, "credentials"),
       TABLE_ID((short)2, "tableId"),
@@ -34460,7 +34460,7 @@ import org.slf4j.LoggerFactory;
     public ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
@@ -35022,7 +35022,7 @@ import org.slf4j.LoggerFactory;
     public String interfaceMatch; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)2, "credentials"),
       NAMESPACE_ID((short)3, "namespaceId"),
@@ -35782,7 +35782,7 @@ import org.slf4j.LoggerFactory;
     public ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ConfigurationType.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ConfigurationType.java b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ConfigurationType.java
index f5be98c..7399802 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ConfigurationType.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ConfigurationType.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum ConfigurationType implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum ConfigurationType implements org.apache.thrift.TEnum {
   CURRENT(0),
   SITE(1),
   DEFAULT(2);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/SecurityErrorCode.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/SecurityErrorCode.java b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/SecurityErrorCode.java
index 111cffa..754f24e 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/SecurityErrorCode.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/SecurityErrorCode.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum SecurityErrorCode implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum SecurityErrorCode implements org.apache.thrift.TEnum {
   DEFAULT_SECURITY_ERROR(0),
   BAD_CREDENTIALS(1),
   PERMISSION_DENIED(2),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TDiskUsage.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TDiskUsage.java b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TDiskUsage.java
index 1b85d47..1ae011b 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TDiskUsage.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TDiskUsage.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TDiskUsage implements org.apache.thrift.TBase<TDiskUsage, TDiskUsage._Fields>, java.io.Serializable, Cloneable, Comparable<TDiskUsage> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TDiskUsage implements org.apache.thrift.TBase<TDiskUsage, TDiskUsage._Fields>, java.io.Serializable, Cloneable, Comparable<TDiskUsage> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TDiskUsage");
 
   private static final org.apache.thrift.protocol.TField TABLES_FIELD_DESC = new org.apache.thrift.protocol.TField("tables", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -64,7 +64,7 @@ import org.slf4j.LoggerFactory;
   public long usage; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     TABLES((short)1, "tables"),
     USAGE((short)2, "usage");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TableOperation.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TableOperation.java b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TableOperation.java
index 7716823..4730276 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TableOperation.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TableOperation.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum TableOperation implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum TableOperation implements org.apache.thrift.TEnum {
   CREATE(0),
   DELETE(1),
   RENAME(2),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TableOperationExceptionType.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TableOperationExceptionType.java b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TableOperationExceptionType.java
index baea21e..48b5619 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TableOperationExceptionType.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TableOperationExceptionType.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum TableOperationExceptionType implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum TableOperationExceptionType implements org.apache.thrift.TEnum {
   EXISTS(0),
   NOTFOUND(1),
   OFFLINE(2),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftSecurityException.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftSecurityException.java b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftSecurityException.java
index a6500e5..9e94830 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftSecurityException.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftSecurityException.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ThriftSecurityException extends TException implements org.apache.thrift.TBase<ThriftSecurityException, ThriftSecurityException._Fields>, java.io.Serializable, Cloneable, Comparable<ThriftSecurityException> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ThriftSecurityException extends TException implements org.apache.thrift.TBase<ThriftSecurityException, ThriftSecurityException._Fields>, java.io.Serializable, Cloneable, Comparable<ThriftSecurityException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ThriftSecurityException");
 
   private static final org.apache.thrift.protocol.TField USER_FIELD_DESC = new org.apache.thrift.protocol.TField("user", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -68,7 +68,7 @@ import org.slf4j.LoggerFactory;
   public SecurityErrorCode code; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     USER((short)1, "user"),
     /**
      * 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftTableOperationException.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftTableOperationException.java b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftTableOperationException.java
index 0c8ab4b..fad7ea7 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftTableOperationException.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftTableOperationException.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ThriftTableOperationException extends TException implements org.apache.thrift.TBase<ThriftTableOperationException, ThriftTableOperationException._Fields>, java.io.Serializable, Cloneable, Comparable<ThriftTableOperationException> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ThriftTableOperationException extends TException implements org.apache.thrift.TBase<ThriftTableOperationException, ThriftTableOperationException._Fields>, java.io.Serializable, Cloneable, Comparable<ThriftTableOperationException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ThriftTableOperationException");
 
   private static final org.apache.thrift.protocol.TField TABLE_ID_FIELD_DESC = new org.apache.thrift.protocol.TField("tableId", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -78,7 +78,7 @@ import org.slf4j.LoggerFactory;
   public String description; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     TABLE_ID((short)1, "tableId"),
     TABLE_NAME((short)2, "tableName"),
     /**

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftTest.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftTest.java b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftTest.java
index 5f785ff..c4af921 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftTest.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftTest.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ThriftTest {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ThriftTest {
 
   public interface Iface {
 
@@ -545,7 +545,7 @@ import org.slf4j.LoggerFactory;
 
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
 ;
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -793,7 +793,7 @@ import org.slf4j.LoggerFactory;
     public boolean success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -1145,7 +1145,7 @@ import org.slf4j.LoggerFactory;
 
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
 ;
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -1393,7 +1393,7 @@ import org.slf4j.LoggerFactory;
     public boolean success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -1745,7 +1745,7 @@ import org.slf4j.LoggerFactory;
 
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
 ;
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -1995,7 +1995,7 @@ import org.slf4j.LoggerFactory;
     public ThriftSecurityException ex; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       EX((short)1, "ex");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/client/mapreduce/lib/impl/DistributedCacheHelper.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/lib/impl/DistributedCacheHelper.java b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/lib/impl/DistributedCacheHelper.java
index c694b9a..a5e603b 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/lib/impl/DistributedCacheHelper.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/lib/impl/DistributedCacheHelper.java
@@ -20,7 +20,6 @@ import java.io.IOException;
 import java.net.URI;
 
 import org.apache.hadoop.conf.Configuration;
-import org.apache.hadoop.filecache.DistributedCache;
 import org.apache.hadoop.fs.Path;
 
 /**
@@ -33,20 +32,20 @@ public class DistributedCacheHelper {
    * @since 1.6.0
    */
   public static void addCacheFile(URI uri, Configuration conf) {
-    DistributedCache.addCacheFile(uri, conf);
+    org.apache.hadoop.filecache.DistributedCache.addCacheFile(uri, conf);
   }
 
   /**
    * @since 1.6.0
    */
   public static URI[] getCacheFiles(Configuration conf) throws IOException {
-    return DistributedCache.getCacheFiles(conf);
+    return org.apache.hadoop.filecache.DistributedCache.getCacheFiles(conf);
   }
 
   /**
    * @since 1.6.0
    */
   public static Path[] getLocalCacheFiles(Configuration conf) throws IOException {
-    return DistributedCache.getLocalCacheFiles(conf);
+    return org.apache.hadoop.filecache.DistributedCache.getLocalCacheFiles(conf);
   }
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/InitialMultiScan.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/InitialMultiScan.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/InitialMultiScan.java
index d4d5424..d124c14 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/InitialMultiScan.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/InitialMultiScan.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class InitialMultiScan implements org.apache.thrift.TBase<InitialMultiScan, InitialMultiScan._Fields>, java.io.Serializable, Cloneable, Comparable<InitialMultiScan> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class InitialMultiScan implements org.apache.thrift.TBase<InitialMultiScan, InitialMultiScan._Fields>, java.io.Serializable, Cloneable, Comparable<InitialMultiScan> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("InitialMultiScan");
 
   private static final org.apache.thrift.protocol.TField SCAN_ID_FIELD_DESC = new org.apache.thrift.protocol.TField("scanID", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -64,7 +64,7 @@ import org.slf4j.LoggerFactory;
   public MultiScanResult result; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     SCAN_ID((short)1, "scanID"),
     RESULT((short)2, "result");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/InitialScan.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/InitialScan.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/InitialScan.java
index 001bc51..38239d7 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/InitialScan.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/InitialScan.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class InitialScan implements org.apache.thrift.TBase<InitialScan, InitialScan._Fields>, java.io.Serializable, Cloneable, Comparable<InitialScan> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class InitialScan implements org.apache.thrift.TBase<InitialScan, InitialScan._Fields>, java.io.Serializable, Cloneable, Comparable<InitialScan> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("InitialScan");
 
   private static final org.apache.thrift.protocol.TField SCAN_ID_FIELD_DESC = new org.apache.thrift.protocol.TField("scanID", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -64,7 +64,7 @@ import org.slf4j.LoggerFactory;
   public ScanResult result; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     SCAN_ID((short)1, "scanID"),
     RESULT((short)2, "result");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/IterInfo.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/IterInfo.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/IterInfo.java
index 6135634..890a6b8 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/IterInfo.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/IterInfo.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class IterInfo implements org.apache.thrift.TBase<IterInfo, IterInfo._Fields>, java.io.Serializable, Cloneable, Comparable<IterInfo> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class IterInfo implements org.apache.thrift.TBase<IterInfo, IterInfo._Fields>, java.io.Serializable, Cloneable, Comparable<IterInfo> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("IterInfo");
 
   private static final org.apache.thrift.protocol.TField PRIORITY_FIELD_DESC = new org.apache.thrift.protocol.TField("priority", org.apache.thrift.protocol.TType.I32, (short)1);
@@ -66,7 +66,7 @@ import org.slf4j.LoggerFactory;
   public String iterName; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     PRIORITY((short)1, "priority"),
     CLASS_NAME((short)2, "className"),
     ITER_NAME((short)3, "iterName");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/MapFileInfo.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/MapFileInfo.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/MapFileInfo.java
index 8598818..0fbf04f 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/MapFileInfo.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/MapFileInfo.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class MapFileInfo implements org.apache.thrift.TBase<MapFileInfo, MapFileInfo._Fields>, java.io.Serializable, Cloneable, Comparable<MapFileInfo> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class MapFileInfo implements org.apache.thrift.TBase<MapFileInfo, MapFileInfo._Fields>, java.io.Serializable, Cloneable, Comparable<MapFileInfo> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("MapFileInfo");
 
   private static final org.apache.thrift.protocol.TField ESTIMATED_SIZE_FIELD_DESC = new org.apache.thrift.protocol.TField("estimatedSize", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public long estimatedSize; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     ESTIMATED_SIZE((short)1, "estimatedSize");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/MultiScanResult.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/MultiScanResult.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/MultiScanResult.java
index d7c0374..0140a68 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/MultiScanResult.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/MultiScanResult.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class MultiScanResult implements org.apache.thrift.TBase<MultiScanResult, MultiScanResult._Fields>, java.io.Serializable, Cloneable, Comparable<MultiScanResult> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class MultiScanResult implements org.apache.thrift.TBase<MultiScanResult, MultiScanResult._Fields>, java.io.Serializable, Cloneable, Comparable<MultiScanResult> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("MultiScanResult");
 
   private static final org.apache.thrift.protocol.TField RESULTS_FIELD_DESC = new org.apache.thrift.protocol.TField("results", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -74,7 +74,7 @@ import org.slf4j.LoggerFactory;
   public boolean more; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     RESULTS((short)1, "results"),
     FAILURES((short)2, "failures"),
     FULL_SCANS((short)3, "fullScans"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/ScanResult.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/ScanResult.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/ScanResult.java
index ce418a6..b936d2b 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/ScanResult.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/ScanResult.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ScanResult implements org.apache.thrift.TBase<ScanResult, ScanResult._Fields>, java.io.Serializable, Cloneable, Comparable<ScanResult> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ScanResult implements org.apache.thrift.TBase<ScanResult, ScanResult._Fields>, java.io.Serializable, Cloneable, Comparable<ScanResult> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ScanResult");
 
   private static final org.apache.thrift.protocol.TField RESULTS_FIELD_DESC = new org.apache.thrift.protocol.TField("results", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -64,7 +64,7 @@ import org.slf4j.LoggerFactory;
   public boolean more; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     RESULTS((short)1, "results"),
     MORE((short)2, "more");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/TCMResult.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/TCMResult.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/TCMResult.java
index 598bd48..7c60cd1 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/TCMResult.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/TCMResult.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TCMResult implements org.apache.thrift.TBase<TCMResult, TCMResult._Fields>, java.io.Serializable, Cloneable, Comparable<TCMResult> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TCMResult implements org.apache.thrift.TBase<TCMResult, TCMResult._Fields>, java.io.Serializable, Cloneable, Comparable<TCMResult> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TCMResult");
 
   private static final org.apache.thrift.protocol.TField CMID_FIELD_DESC = new org.apache.thrift.protocol.TField("cmid", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -68,7 +68,7 @@ import org.slf4j.LoggerFactory;
   public TCMStatus status; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     CMID((short)1, "cmid"),
     /**
      * 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/TCMStatus.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/TCMStatus.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/TCMStatus.java
index ee4592c..993e9e2 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/TCMStatus.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/TCMStatus.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum TCMStatus implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum TCMStatus implements org.apache.thrift.TEnum {
   ACCEPTED(0),
   REJECTED(1),
   VIOLATED(2),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/TColumn.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/TColumn.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/TColumn.java
index 125cece..127f7c6 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/TColumn.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/TColumn.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TColumn implements org.apache.thrift.TBase<TColumn, TColumn._Fields>, java.io.Serializable, Cloneable, Comparable<TColumn> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TColumn implements org.apache.thrift.TBase<TColumn, TColumn._Fields>, java.io.Serializable, Cloneable, Comparable<TColumn> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TColumn");
 
   private static final org.apache.thrift.protocol.TField COLUMN_FAMILY_FIELD_DESC = new org.apache.thrift.protocol.TField("columnFamily", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -66,7 +66,7 @@ import org.slf4j.LoggerFactory;
   public ByteBuffer columnVisibility; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     COLUMN_FAMILY((short)1, "columnFamily"),
     COLUMN_QUALIFIER((short)2, "columnQualifier"),
     COLUMN_VISIBILITY((short)3, "columnVisibility");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/TCondition.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/TCondition.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/TCondition.java
index 9fc3968..a4ae6df 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/TCondition.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/TCondition.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TCondition implements org.apache.thrift.TBase<TCondition, TCondition._Fields>, java.io.Serializable, Cloneable, Comparable<TCondition> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TCondition implements org.apache.thrift.TBase<TCondition, TCondition._Fields>, java.io.Serializable, Cloneable, Comparable<TCondition> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TCondition");
 
   private static final org.apache.thrift.protocol.TField CF_FIELD_DESC = new org.apache.thrift.protocol.TField("cf", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -74,7 +74,7 @@ import org.slf4j.LoggerFactory;
   public ByteBuffer iterators; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     CF((short)1, "cf"),
     CQ((short)2, "cq"),
     CV((short)3, "cv"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/TConditionalMutation.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/TConditionalMutation.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/TConditionalMutation.java
index 3d49c45..8c9f0a6 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/TConditionalMutation.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/TConditionalMutation.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TConditionalMutation implements org.apache.thrift.TBase<TConditionalMutation, TConditionalMutation._Fields>, java.io.Serializable, Cloneable, Comparable<TConditionalMutation> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TConditionalMutation implements org.apache.thrift.TBase<TConditionalMutation, TConditionalMutation._Fields>, java.io.Serializable, Cloneable, Comparable<TConditionalMutation> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TConditionalMutation");
 
   private static final org.apache.thrift.protocol.TField CONDITIONS_FIELD_DESC = new org.apache.thrift.protocol.TField("conditions", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -66,7 +66,7 @@ import org.slf4j.LoggerFactory;
   public long id; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     CONDITIONS((short)1, "conditions"),
     MUTATION((short)2, "mutation"),
     ID((short)3, "id");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/TConditionalSession.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/TConditionalSession.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/TConditionalSession.java
index 646dbdb..eb08623 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/TConditionalSession.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/TConditionalSession.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TConditionalSession implements org.apache.thrift.TBase<TConditionalSession, TConditionalSession._Fields>, java.io.Serializable, Cloneable, Comparable<TConditionalSession> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TConditionalSession implements org.apache.thrift.TBase<TConditionalSession, TConditionalSession._Fields>, java.io.Serializable, Cloneable, Comparable<TConditionalSession> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TConditionalSession");
 
   private static final org.apache.thrift.protocol.TField SESSION_ID_FIELD_DESC = new org.apache.thrift.protocol.TField("sessionId", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -66,7 +66,7 @@ import org.slf4j.LoggerFactory;
   public long ttl; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     SESSION_ID((short)1, "sessionId"),
     TSERVER_LOCK((short)2, "tserverLock"),
     TTL((short)3, "ttl");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/TConstraintViolationSummary.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/TConstraintViolationSummary.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/TConstraintViolationSummary.java
index d841eff..1dc51e3 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/TConstraintViolationSummary.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/TConstraintViolationSummary.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TConstraintViolationSummary implements org.apache.thrift.TBase<TConstraintViolationSummary, TConstraintViolationSummary._Fields>, java.io.Serializable, Cloneable, Comparable<TConstraintViolationSummary> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TConstraintViolationSummary implements org.apache.thrift.TBase<TConstraintViolationSummary, TConstraintViolationSummary._Fields>, java.io.Serializable, Cloneable, Comparable<TConstraintViolationSummary> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TConstraintViolationSummary");
 
   private static final org.apache.thrift.protocol.TField CONSTRAIN_CLASS_FIELD_DESC = new org.apache.thrift.protocol.TField("constrainClass", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -68,7 +68,7 @@ import org.slf4j.LoggerFactory;
   public long numberOfViolatingMutations; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     CONSTRAIN_CLASS((short)1, "constrainClass"),
     VIOLATION_CODE((short)2, "violationCode"),
     VIOLATION_DESCRIPTION((short)3, "violationDescription"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/TKey.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/TKey.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/TKey.java
index 4f05c66..2b81651 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/TKey.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/TKey.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TKey implements org.apache.thrift.TBase<TKey, TKey._Fields>, java.io.Serializable, Cloneable, Comparable<TKey> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TKey implements org.apache.thrift.TBase<TKey, TKey._Fields>, java.io.Serializable, Cloneable, Comparable<TKey> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TKey");
 
   private static final org.apache.thrift.protocol.TField ROW_FIELD_DESC = new org.apache.thrift.protocol.TField("row", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -70,7 +70,7 @@ import org.slf4j.LoggerFactory;
   public long timestamp; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     ROW((short)1, "row"),
     COL_FAMILY((short)2, "colFamily"),
     COL_QUALIFIER((short)3, "colQualifier"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/TKeyExtent.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/TKeyExtent.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/TKeyExtent.java
index b83fc1a..20f1fea 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/TKeyExtent.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/TKeyExtent.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TKeyExtent implements org.apache.thrift.TBase<TKeyExtent, TKeyExtent._Fields>, java.io.Serializable, Cloneable, Comparable<TKeyExtent> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TKeyExtent implements org.apache.thrift.TBase<TKeyExtent, TKeyExtent._Fields>, java.io.Serializable, Cloneable, Comparable<TKeyExtent> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TKeyExtent");
 
   private static final org.apache.thrift.protocol.TField TABLE_FIELD_DESC = new org.apache.thrift.protocol.TField("table", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -66,7 +66,7 @@ import org.slf4j.LoggerFactory;
   public ByteBuffer prevEndRow; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     TABLE((short)1, "table"),
     END_ROW((short)2, "endRow"),
     PREV_END_ROW((short)3, "prevEndRow");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/TKeyValue.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/TKeyValue.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/TKeyValue.java
index 4c47c69..75161b0 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/TKeyValue.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/TKeyValue.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TKeyValue implements org.apache.thrift.TBase<TKeyValue, TKeyValue._Fields>, java.io.Serializable, Cloneable, Comparable<TKeyValue> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TKeyValue implements org.apache.thrift.TBase<TKeyValue, TKeyValue._Fields>, java.io.Serializable, Cloneable, Comparable<TKeyValue> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TKeyValue");
 
   private static final org.apache.thrift.protocol.TField KEY_FIELD_DESC = new org.apache.thrift.protocol.TField("key", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -64,7 +64,7 @@ import org.slf4j.LoggerFactory;
   public ByteBuffer value; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     KEY((short)1, "key"),
     VALUE((short)2, "value");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/TMutation.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/TMutation.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/TMutation.java
index 1e00047..ecaf87c 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/TMutation.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/TMutation.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TMutation implements org.apache.thrift.TBase<TMutation, TMutation._Fields>, java.io.Serializable, Cloneable, Comparable<TMutation> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TMutation implements org.apache.thrift.TBase<TMutation, TMutation._Fields>, java.io.Serializable, Cloneable, Comparable<TMutation> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TMutation");
 
   private static final org.apache.thrift.protocol.TField ROW_FIELD_DESC = new org.apache.thrift.protocol.TField("row", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -68,7 +68,7 @@ import org.slf4j.LoggerFactory;
   public int entries; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     ROW((short)1, "row"),
     DATA((short)2, "data"),
     VALUES((short)3, "values"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/TRange.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/TRange.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/TRange.java
index 58e805f..0ad791c 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/TRange.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/TRange.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TRange implements org.apache.thrift.TBase<TRange, TRange._Fields>, java.io.Serializable, Cloneable, Comparable<TRange> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TRange implements org.apache.thrift.TBase<TRange, TRange._Fields>, java.io.Serializable, Cloneable, Comparable<TRange> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TRange");
 
   private static final org.apache.thrift.protocol.TField START_FIELD_DESC = new org.apache.thrift.protocol.TField("start", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -72,7 +72,7 @@ import org.slf4j.LoggerFactory;
   public boolean infiniteStopKey; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     START((short)1, "start"),
     STOP((short)2, "stop"),
     START_KEY_INCLUSIVE((short)3, "startKeyInclusive"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/UpdateErrors.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/UpdateErrors.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/UpdateErrors.java
index 55a0602..f2b53ad 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/UpdateErrors.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/UpdateErrors.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class UpdateErrors implements org.apache.thrift.TBase<UpdateErrors, UpdateErrors._Fields>, java.io.Serializable, Cloneable, Comparable<UpdateErrors> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class UpdateErrors implements org.apache.thrift.TBase<UpdateErrors, UpdateErrors._Fields>, java.io.Serializable, Cloneable, Comparable<UpdateErrors> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("UpdateErrors");
 
   private static final org.apache.thrift.protocol.TField FAILED_EXTENTS_FIELD_DESC = new org.apache.thrift.protocol.TField("failedExtents", org.apache.thrift.protocol.TType.MAP, (short)1);
@@ -66,7 +66,7 @@ import org.slf4j.LoggerFactory;
   public Map<TKeyExtent,org.apache.accumulo.core.client.impl.thrift.SecurityErrorCode> authorizationFailures; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     FAILED_EXTENTS((short)1, "failedExtents"),
     VIOLATION_SUMMARIES((short)2, "violationSummaries"),
     AUTHORIZATION_FAILURES((short)3, "authorizationFailures");


[12/25] accumulo git commit: ACCUMULO-3759 More build warnings on Java 8

Posted by ct...@apache.org.
ACCUMULO-3759 More build warnings on Java 8

* Clean up build output while generating example configs
* Fix javac warnings from thrift
* Enable specifying different findbugs version to build on jdk8


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

Branch: refs/heads/1.7
Commit: bbcc6da446b737507dfd9c486b5673055fbdf0ab
Parents: b636ff2
Author: Christopher Tubbs <ct...@apache.org>
Authored: Thu Apr 30 13:00:18 2015 -0400
Committer: Christopher Tubbs <ct...@apache.org>
Committed: Thu Apr 30 13:29:30 2015 -0400

----------------------------------------------------------------------
 .../main/scripts/generate-example-configs.sh    |   7 +-
 .../core/client/impl/thrift/ClientService.java  | 122 ++++----
 .../client/impl/thrift/ConfigurationType.java   |   2 +-
 .../client/impl/thrift/SecurityErrorCode.java   |   2 +-
 .../core/client/impl/thrift/TDiskUsage.java     |   4 +-
 .../core/client/impl/thrift/TableOperation.java |   2 +-
 .../thrift/TableOperationExceptionType.java     |   2 +-
 .../impl/thrift/ThriftSecurityException.java    |   4 +-
 .../thrift/ThriftTableOperationException.java   |   4 +-
 .../core/client/impl/thrift/ThriftTest.java     |  14 +-
 .../lib/impl/DistributedCacheHelper.java        |   7 +-
 .../core/data/thrift/InitialMultiScan.java      |   4 +-
 .../accumulo/core/data/thrift/InitialScan.java  |   4 +-
 .../accumulo/core/data/thrift/IterInfo.java     |   4 +-
 .../accumulo/core/data/thrift/MapFileInfo.java  |   4 +-
 .../core/data/thrift/MultiScanResult.java       |   4 +-
 .../accumulo/core/data/thrift/ScanResult.java   |   4 +-
 .../accumulo/core/data/thrift/TCMResult.java    |   4 +-
 .../accumulo/core/data/thrift/TCMStatus.java    |   2 +-
 .../accumulo/core/data/thrift/TColumn.java      |   4 +-
 .../accumulo/core/data/thrift/TCondition.java   |   4 +-
 .../core/data/thrift/TConditionalMutation.java  |   4 +-
 .../core/data/thrift/TConditionalSession.java   |   4 +-
 .../thrift/TConstraintViolationSummary.java     |   4 +-
 .../apache/accumulo/core/data/thrift/TKey.java  |   4 +-
 .../accumulo/core/data/thrift/TKeyExtent.java   |   4 +-
 .../accumulo/core/data/thrift/TKeyValue.java    |   4 +-
 .../accumulo/core/data/thrift/TMutation.java    |   4 +-
 .../accumulo/core/data/thrift/TRange.java       |   4 +-
 .../accumulo/core/data/thrift/UpdateErrors.java |   4 +-
 .../core/gc/thrift/GCMonitorService.java        |   6 +-
 .../accumulo/core/gc/thrift/GCStatus.java       |   4 +-
 .../accumulo/core/gc/thrift/GcCycleStats.java   |   4 +-
 .../accumulo/core/master/thrift/Compacting.java |   4 +-
 .../accumulo/core/master/thrift/DeadServer.java |   4 +-
 .../core/master/thrift/FateOperation.java       |   2 +-
 .../core/master/thrift/FateService.java         |  18 +-
 .../core/master/thrift/MasterClientService.java |  54 ++--
 .../core/master/thrift/MasterGoalState.java     |   2 +-
 .../core/master/thrift/MasterMonitorInfo.java   |   4 +-
 .../core/master/thrift/MasterState.java         |   2 +-
 .../core/master/thrift/RecoveryException.java   |   4 +-
 .../core/master/thrift/RecoveryStatus.java      |   4 +-
 .../accumulo/core/master/thrift/TableInfo.java  |   4 +-
 .../core/master/thrift/TabletLoadState.java     |   2 +-
 .../core/master/thrift/TabletServerStatus.java  |   4 +-
 .../core/master/thrift/TabletSplit.java         |   4 +-
 .../core/security/thrift/TCredentials.java      |   4 +-
 .../core/tabletserver/thrift/ActionStats.java   |   4 +-
 .../tabletserver/thrift/ActiveCompaction.java   |   4 +-
 .../core/tabletserver/thrift/ActiveScan.java    |   4 +-
 .../tabletserver/thrift/CompactionReason.java   |   2 +-
 .../tabletserver/thrift/CompactionType.java     |   2 +-
 .../thrift/ConstraintViolationException.java    |   4 +-
 .../tabletserver/thrift/IteratorConfig.java     |   4 +-
 .../thrift/NoSuchScanIDException.java           |   4 +-
 .../thrift/NotServingTabletException.java       |   4 +-
 .../core/tabletserver/thrift/ScanState.java     |   2 +-
 .../core/tabletserver/thrift/ScanType.java      |   2 +-
 .../tabletserver/thrift/TIteratorSetting.java   |   4 +-
 .../thrift/TabletClientService.java             | 100 +++---
 .../core/tabletserver/thrift/TabletStats.java   |   4 +-
 .../thrift/TooManyFilesException.java           |   4 +-
 core/src/main/scripts/generate-thrift.sh        |  50 +--
 pom.xml                                         |   6 +-
 .../proxy/thrift/AccumuloException.java         |   4 +-
 .../accumulo/proxy/thrift/AccumuloProxy.java    | 308 +++++++++----------
 .../proxy/thrift/AccumuloSecurityException.java |   4 +-
 .../accumulo/proxy/thrift/ActiveCompaction.java |   4 +-
 .../accumulo/proxy/thrift/ActiveScan.java       |   4 +-
 .../accumulo/proxy/thrift/BatchScanOptions.java |   4 +-
 .../apache/accumulo/proxy/thrift/Column.java    |   4 +-
 .../accumulo/proxy/thrift/ColumnUpdate.java     |   4 +-
 .../accumulo/proxy/thrift/CompactionReason.java |   2 +-
 .../accumulo/proxy/thrift/CompactionType.java   |   2 +-
 .../apache/accumulo/proxy/thrift/Condition.java |   4 +-
 .../proxy/thrift/ConditionalStatus.java         |   2 +-
 .../proxy/thrift/ConditionalUpdates.java        |   4 +-
 .../proxy/thrift/ConditionalWriterOptions.java  |   4 +-
 .../apache/accumulo/proxy/thrift/DiskUsage.java |   4 +-
 .../accumulo/proxy/thrift/IteratorScope.java    |   2 +-
 .../accumulo/proxy/thrift/IteratorSetting.java  |   4 +-
 .../org/apache/accumulo/proxy/thrift/Key.java   |   4 +-
 .../apache/accumulo/proxy/thrift/KeyExtent.java |   4 +-
 .../apache/accumulo/proxy/thrift/KeyValue.java  |   4 +-
 .../accumulo/proxy/thrift/KeyValueAndPeek.java  |   4 +-
 .../thrift/MutationsRejectedException.java      |   4 +-
 .../proxy/thrift/NoMoreEntriesException.java    |   4 +-
 .../accumulo/proxy/thrift/PartialKey.java       |   2 +-
 .../org/apache/accumulo/proxy/thrift/Range.java |   4 +-
 .../accumulo/proxy/thrift/ScanColumn.java       |   4 +-
 .../accumulo/proxy/thrift/ScanOptions.java      |   4 +-
 .../accumulo/proxy/thrift/ScanResult.java       |   4 +-
 .../apache/accumulo/proxy/thrift/ScanState.java |   2 +-
 .../apache/accumulo/proxy/thrift/ScanType.java  |   2 +-
 .../accumulo/proxy/thrift/SystemPermission.java |   2 +-
 .../proxy/thrift/TableExistsException.java      |   4 +-
 .../proxy/thrift/TableNotFoundException.java    |   4 +-
 .../accumulo/proxy/thrift/TablePermission.java  |   2 +-
 .../apache/accumulo/proxy/thrift/TimeType.java  |   2 +-
 .../accumulo/proxy/thrift/UnknownScanner.java   |   4 +-
 .../accumulo/proxy/thrift/UnknownWriter.java    |   4 +-
 .../accumulo/proxy/thrift/WriterOptions.java    |   4 +-
 .../accumulo/trace/thrift/RemoteSpan.java       |   4 +-
 .../accumulo/trace/thrift/SpanReceiver.java     |   4 +-
 .../org/apache/accumulo/trace/thrift/TInfo.java |   4 +-
 .../accumulo/trace/thrift/TestService.java      |   6 +-
 trace/src/main/scripts/generate-thrift.sh       |   4 +
 108 files changed, 523 insertions(+), 513 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/assemble/src/main/scripts/generate-example-configs.sh
----------------------------------------------------------------------
diff --git a/assemble/src/main/scripts/generate-example-configs.sh b/assemble/src/main/scripts/generate-example-configs.sh
index 16c9f4f..9dfbfe1 100755
--- a/assemble/src/main/scripts/generate-example-configs.sh
+++ b/assemble/src/main/scripts/generate-example-configs.sh
@@ -17,9 +17,12 @@
 
 # This script will regenerate the example configuration files for the tarball
 
+out=target/bootstrap-config.out
+
+echo 'Generating example scripts...' > $out
 for s in 1GB 2GB 3GB 512MB
 do
-  bin/bootstrap_config.sh -o -d target/example-configs/$s/standalone -s $s -j -v 2
-  bin/bootstrap_config.sh -o -d target/example-configs/$s/native-standalone -s $s -n -v 2
+  bin/bootstrap_config.sh -o -d target/example-configs/$s/standalone -s $s -j -v 2 >> $out 2>&1
+  bin/bootstrap_config.sh -o -d target/example-configs/$s/native-standalone -s $s -n -v 2 >> $out 2>&1
 done
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ClientService.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ClientService.java b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ClientService.java
index 638a8b7..5dd2cd5 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ClientService.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ClientService.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ClientService {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ClientService {
 
   public interface Iface {
 
@@ -4776,7 +4776,7 @@ import org.slf4j.LoggerFactory;
 
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
 ;
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -5024,7 +5024,7 @@ import org.slf4j.LoggerFactory;
     public String success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -5376,7 +5376,7 @@ import org.slf4j.LoggerFactory;
 
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
 ;
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -5624,7 +5624,7 @@ import org.slf4j.LoggerFactory;
     public String success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -5976,7 +5976,7 @@ import org.slf4j.LoggerFactory;
 
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
 ;
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -6224,7 +6224,7 @@ import org.slf4j.LoggerFactory;
     public String success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -6590,7 +6590,7 @@ import org.slf4j.LoggerFactory;
     public boolean setTime; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)8, "credentials"),
       TID((short)3, "tid"),
@@ -7587,7 +7587,7 @@ import org.slf4j.LoggerFactory;
     public ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
@@ -8192,7 +8192,7 @@ import org.slf4j.LoggerFactory;
     public long tid; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       TID((short)2, "tid");
 
@@ -8647,7 +8647,7 @@ import org.slf4j.LoggerFactory;
     public boolean success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -9001,7 +9001,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.security.thrift.TCredentials credentials; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       CREDENTIALS((short)2, "credentials");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -9360,7 +9360,7 @@ import org.slf4j.LoggerFactory;
     public ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -9718,7 +9718,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.security.thrift.TCredentials credentials; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TABLES((short)2, "tables"),
       CREDENTIALS((short)1, "credentials");
 
@@ -10228,7 +10228,7 @@ import org.slf4j.LoggerFactory;
     public ThriftTableOperationException toe; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec"),
       TOE((short)2, "toe");
@@ -10838,7 +10838,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.security.thrift.TCredentials credentials; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       CREDENTIALS((short)3, "credentials");
 
@@ -11302,7 +11302,7 @@ import org.slf4j.LoggerFactory;
     public ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -11811,7 +11811,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer password; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)5, "tinfo"),
       CREDENTIALS((short)6, "credentials"),
       PRINCIPAL((short)2, "principal"),
@@ -12480,7 +12480,7 @@ import org.slf4j.LoggerFactory;
     public ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -12840,7 +12840,7 @@ import org.slf4j.LoggerFactory;
     public String principal; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)4, "credentials"),
       PRINCIPAL((short)2, "principal");
@@ -13400,7 +13400,7 @@ import org.slf4j.LoggerFactory;
     public ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -13762,7 +13762,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer password; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)4, "tinfo"),
       CREDENTIALS((short)5, "credentials"),
       PRINCIPAL((short)2, "principal"),
@@ -14431,7 +14431,7 @@ import org.slf4j.LoggerFactory;
     public ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -14789,7 +14789,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.security.thrift.TCredentials credentials; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)2, "credentials");
 
@@ -15253,7 +15253,7 @@ import org.slf4j.LoggerFactory;
     public ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -15711,7 +15711,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.security.thrift.TCredentials toAuth; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)2, "credentials"),
       TO_AUTH((short)3, "toAuth");
@@ -16278,7 +16278,7 @@ import org.slf4j.LoggerFactory;
     public ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -16738,7 +16738,7 @@ import org.slf4j.LoggerFactory;
     public List<ByteBuffer> authorizations; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)4, "tinfo"),
       CREDENTIALS((short)5, "credentials"),
       PRINCIPAL((short)2, "principal"),
@@ -17445,7 +17445,7 @@ import org.slf4j.LoggerFactory;
     public ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -17805,7 +17805,7 @@ import org.slf4j.LoggerFactory;
     public String principal; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)4, "credentials"),
       PRINCIPAL((short)2, "principal");
@@ -18367,7 +18367,7 @@ import org.slf4j.LoggerFactory;
     public ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -18876,7 +18876,7 @@ import org.slf4j.LoggerFactory;
     public byte sysPerm; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)4, "tinfo"),
       CREDENTIALS((short)5, "credentials"),
       PRINCIPAL((short)2, "principal"),
@@ -19534,7 +19534,7 @@ import org.slf4j.LoggerFactory;
     public ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -19996,7 +19996,7 @@ import org.slf4j.LoggerFactory;
     public byte tblPerm; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)5, "tinfo"),
       CREDENTIALS((short)6, "credentials"),
       PRINCIPAL((short)2, "principal"),
@@ -20754,7 +20754,7 @@ import org.slf4j.LoggerFactory;
     public ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
@@ -21316,7 +21316,7 @@ import org.slf4j.LoggerFactory;
     public byte tblNspcPerm; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)2, "credentials"),
       PRINCIPAL((short)3, "principal"),
@@ -22074,7 +22074,7 @@ import org.slf4j.LoggerFactory;
     public ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
@@ -22634,7 +22634,7 @@ import org.slf4j.LoggerFactory;
     public byte permission; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)4, "tinfo"),
       CREDENTIALS((short)5, "credentials"),
       PRINCIPAL((short)2, "principal"),
@@ -23290,7 +23290,7 @@ import org.slf4j.LoggerFactory;
     public ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -23652,7 +23652,7 @@ import org.slf4j.LoggerFactory;
     public byte permission; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)4, "tinfo"),
       CREDENTIALS((short)5, "credentials"),
       PRINCIPAL((short)2, "principal"),
@@ -24308,7 +24308,7 @@ import org.slf4j.LoggerFactory;
     public ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -24672,7 +24672,7 @@ import org.slf4j.LoggerFactory;
     public byte permission; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)5, "tinfo"),
       CREDENTIALS((short)6, "credentials"),
       PRINCIPAL((short)2, "principal"),
@@ -25428,7 +25428,7 @@ import org.slf4j.LoggerFactory;
     public ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
 
@@ -25892,7 +25892,7 @@ import org.slf4j.LoggerFactory;
     public byte permission; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)5, "tinfo"),
       CREDENTIALS((short)6, "credentials"),
       PRINCIPAL((short)2, "principal"),
@@ -26648,7 +26648,7 @@ import org.slf4j.LoggerFactory;
     public ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
 
@@ -27112,7 +27112,7 @@ import org.slf4j.LoggerFactory;
     public byte permission; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)2, "credentials"),
       PRINCIPAL((short)3, "principal"),
@@ -27868,7 +27868,7 @@ import org.slf4j.LoggerFactory;
     public ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
 
@@ -28332,7 +28332,7 @@ import org.slf4j.LoggerFactory;
     public byte permission; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)2, "credentials"),
       PRINCIPAL((short)3, "principal"),
@@ -29088,7 +29088,7 @@ import org.slf4j.LoggerFactory;
     public ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
 
@@ -29552,7 +29552,7 @@ import org.slf4j.LoggerFactory;
     public ConfigurationType type; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       CREDENTIALS((short)3, "credentials"),
       /**
@@ -30124,7 +30124,7 @@ import org.slf4j.LoggerFactory;
     public Map<String,String> success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -30534,7 +30534,7 @@ import org.slf4j.LoggerFactory;
     public String tableName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)3, "credentials"),
       TABLE_NAME((short)2, "tableName");
@@ -31096,7 +31096,7 @@ import org.slf4j.LoggerFactory;
     public ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       TOPE((short)1, "tope");
 
@@ -31606,7 +31606,7 @@ import org.slf4j.LoggerFactory;
     public String ns; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)2, "credentials"),
       NS((short)3, "ns");
@@ -32168,7 +32168,7 @@ import org.slf4j.LoggerFactory;
     public ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       TOPE((short)1, "tope");
 
@@ -32680,7 +32680,7 @@ import org.slf4j.LoggerFactory;
     public String interfaceMatch; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)4, "credentials"),
       CLASS_NAME((short)2, "className"),
@@ -33338,7 +33338,7 @@ import org.slf4j.LoggerFactory;
     public boolean success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -33700,7 +33700,7 @@ import org.slf4j.LoggerFactory;
     public String interfaceMatch; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)5, "credentials"),
       TABLE_ID((short)2, "tableId"),
@@ -34460,7 +34460,7 @@ import org.slf4j.LoggerFactory;
     public ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
@@ -35022,7 +35022,7 @@ import org.slf4j.LoggerFactory;
     public String interfaceMatch; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)2, "credentials"),
       NAMESPACE_ID((short)3, "namespaceId"),
@@ -35782,7 +35782,7 @@ import org.slf4j.LoggerFactory;
     public ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ConfigurationType.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ConfigurationType.java b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ConfigurationType.java
index f5be98c..7399802 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ConfigurationType.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ConfigurationType.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum ConfigurationType implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum ConfigurationType implements org.apache.thrift.TEnum {
   CURRENT(0),
   SITE(1),
   DEFAULT(2);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/SecurityErrorCode.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/SecurityErrorCode.java b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/SecurityErrorCode.java
index 111cffa..754f24e 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/SecurityErrorCode.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/SecurityErrorCode.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum SecurityErrorCode implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum SecurityErrorCode implements org.apache.thrift.TEnum {
   DEFAULT_SECURITY_ERROR(0),
   BAD_CREDENTIALS(1),
   PERMISSION_DENIED(2),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TDiskUsage.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TDiskUsage.java b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TDiskUsage.java
index 1b85d47..1ae011b 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TDiskUsage.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TDiskUsage.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TDiskUsage implements org.apache.thrift.TBase<TDiskUsage, TDiskUsage._Fields>, java.io.Serializable, Cloneable, Comparable<TDiskUsage> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TDiskUsage implements org.apache.thrift.TBase<TDiskUsage, TDiskUsage._Fields>, java.io.Serializable, Cloneable, Comparable<TDiskUsage> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TDiskUsage");
 
   private static final org.apache.thrift.protocol.TField TABLES_FIELD_DESC = new org.apache.thrift.protocol.TField("tables", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -64,7 +64,7 @@ import org.slf4j.LoggerFactory;
   public long usage; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     TABLES((short)1, "tables"),
     USAGE((short)2, "usage");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TableOperation.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TableOperation.java b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TableOperation.java
index 7716823..4730276 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TableOperation.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TableOperation.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum TableOperation implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum TableOperation implements org.apache.thrift.TEnum {
   CREATE(0),
   DELETE(1),
   RENAME(2),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TableOperationExceptionType.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TableOperationExceptionType.java b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TableOperationExceptionType.java
index baea21e..48b5619 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TableOperationExceptionType.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TableOperationExceptionType.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum TableOperationExceptionType implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum TableOperationExceptionType implements org.apache.thrift.TEnum {
   EXISTS(0),
   NOTFOUND(1),
   OFFLINE(2),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftSecurityException.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftSecurityException.java b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftSecurityException.java
index a6500e5..9e94830 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftSecurityException.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftSecurityException.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ThriftSecurityException extends TException implements org.apache.thrift.TBase<ThriftSecurityException, ThriftSecurityException._Fields>, java.io.Serializable, Cloneable, Comparable<ThriftSecurityException> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ThriftSecurityException extends TException implements org.apache.thrift.TBase<ThriftSecurityException, ThriftSecurityException._Fields>, java.io.Serializable, Cloneable, Comparable<ThriftSecurityException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ThriftSecurityException");
 
   private static final org.apache.thrift.protocol.TField USER_FIELD_DESC = new org.apache.thrift.protocol.TField("user", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -68,7 +68,7 @@ import org.slf4j.LoggerFactory;
   public SecurityErrorCode code; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     USER((short)1, "user"),
     /**
      * 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftTableOperationException.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftTableOperationException.java b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftTableOperationException.java
index 0c8ab4b..fad7ea7 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftTableOperationException.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftTableOperationException.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ThriftTableOperationException extends TException implements org.apache.thrift.TBase<ThriftTableOperationException, ThriftTableOperationException._Fields>, java.io.Serializable, Cloneable, Comparable<ThriftTableOperationException> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ThriftTableOperationException extends TException implements org.apache.thrift.TBase<ThriftTableOperationException, ThriftTableOperationException._Fields>, java.io.Serializable, Cloneable, Comparable<ThriftTableOperationException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ThriftTableOperationException");
 
   private static final org.apache.thrift.protocol.TField TABLE_ID_FIELD_DESC = new org.apache.thrift.protocol.TField("tableId", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -78,7 +78,7 @@ import org.slf4j.LoggerFactory;
   public String description; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     TABLE_ID((short)1, "tableId"),
     TABLE_NAME((short)2, "tableName"),
     /**

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftTest.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftTest.java b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftTest.java
index 5f785ff..c4af921 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftTest.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftTest.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ThriftTest {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ThriftTest {
 
   public interface Iface {
 
@@ -545,7 +545,7 @@ import org.slf4j.LoggerFactory;
 
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
 ;
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -793,7 +793,7 @@ import org.slf4j.LoggerFactory;
     public boolean success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -1145,7 +1145,7 @@ import org.slf4j.LoggerFactory;
 
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
 ;
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -1393,7 +1393,7 @@ import org.slf4j.LoggerFactory;
     public boolean success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -1745,7 +1745,7 @@ import org.slf4j.LoggerFactory;
 
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
 ;
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -1995,7 +1995,7 @@ import org.slf4j.LoggerFactory;
     public ThriftSecurityException ex; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       EX((short)1, "ex");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/client/mapreduce/lib/impl/DistributedCacheHelper.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/lib/impl/DistributedCacheHelper.java b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/lib/impl/DistributedCacheHelper.java
index c694b9a..a5e603b 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/lib/impl/DistributedCacheHelper.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/lib/impl/DistributedCacheHelper.java
@@ -20,7 +20,6 @@ import java.io.IOException;
 import java.net.URI;
 
 import org.apache.hadoop.conf.Configuration;
-import org.apache.hadoop.filecache.DistributedCache;
 import org.apache.hadoop.fs.Path;
 
 /**
@@ -33,20 +32,20 @@ public class DistributedCacheHelper {
    * @since 1.6.0
    */
   public static void addCacheFile(URI uri, Configuration conf) {
-    DistributedCache.addCacheFile(uri, conf);
+    org.apache.hadoop.filecache.DistributedCache.addCacheFile(uri, conf);
   }
 
   /**
    * @since 1.6.0
    */
   public static URI[] getCacheFiles(Configuration conf) throws IOException {
-    return DistributedCache.getCacheFiles(conf);
+    return org.apache.hadoop.filecache.DistributedCache.getCacheFiles(conf);
   }
 
   /**
    * @since 1.6.0
    */
   public static Path[] getLocalCacheFiles(Configuration conf) throws IOException {
-    return DistributedCache.getLocalCacheFiles(conf);
+    return org.apache.hadoop.filecache.DistributedCache.getLocalCacheFiles(conf);
   }
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/InitialMultiScan.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/InitialMultiScan.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/InitialMultiScan.java
index d4d5424..d124c14 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/InitialMultiScan.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/InitialMultiScan.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class InitialMultiScan implements org.apache.thrift.TBase<InitialMultiScan, InitialMultiScan._Fields>, java.io.Serializable, Cloneable, Comparable<InitialMultiScan> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class InitialMultiScan implements org.apache.thrift.TBase<InitialMultiScan, InitialMultiScan._Fields>, java.io.Serializable, Cloneable, Comparable<InitialMultiScan> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("InitialMultiScan");
 
   private static final org.apache.thrift.protocol.TField SCAN_ID_FIELD_DESC = new org.apache.thrift.protocol.TField("scanID", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -64,7 +64,7 @@ import org.slf4j.LoggerFactory;
   public MultiScanResult result; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     SCAN_ID((short)1, "scanID"),
     RESULT((short)2, "result");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/InitialScan.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/InitialScan.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/InitialScan.java
index 001bc51..38239d7 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/InitialScan.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/InitialScan.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class InitialScan implements org.apache.thrift.TBase<InitialScan, InitialScan._Fields>, java.io.Serializable, Cloneable, Comparable<InitialScan> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class InitialScan implements org.apache.thrift.TBase<InitialScan, InitialScan._Fields>, java.io.Serializable, Cloneable, Comparable<InitialScan> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("InitialScan");
 
   private static final org.apache.thrift.protocol.TField SCAN_ID_FIELD_DESC = new org.apache.thrift.protocol.TField("scanID", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -64,7 +64,7 @@ import org.slf4j.LoggerFactory;
   public ScanResult result; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     SCAN_ID((short)1, "scanID"),
     RESULT((short)2, "result");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/IterInfo.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/IterInfo.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/IterInfo.java
index 6135634..890a6b8 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/IterInfo.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/IterInfo.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class IterInfo implements org.apache.thrift.TBase<IterInfo, IterInfo._Fields>, java.io.Serializable, Cloneable, Comparable<IterInfo> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class IterInfo implements org.apache.thrift.TBase<IterInfo, IterInfo._Fields>, java.io.Serializable, Cloneable, Comparable<IterInfo> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("IterInfo");
 
   private static final org.apache.thrift.protocol.TField PRIORITY_FIELD_DESC = new org.apache.thrift.protocol.TField("priority", org.apache.thrift.protocol.TType.I32, (short)1);
@@ -66,7 +66,7 @@ import org.slf4j.LoggerFactory;
   public String iterName; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     PRIORITY((short)1, "priority"),
     CLASS_NAME((short)2, "className"),
     ITER_NAME((short)3, "iterName");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/MapFileInfo.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/MapFileInfo.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/MapFileInfo.java
index 8598818..0fbf04f 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/MapFileInfo.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/MapFileInfo.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class MapFileInfo implements org.apache.thrift.TBase<MapFileInfo, MapFileInfo._Fields>, java.io.Serializable, Cloneable, Comparable<MapFileInfo> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class MapFileInfo implements org.apache.thrift.TBase<MapFileInfo, MapFileInfo._Fields>, java.io.Serializable, Cloneable, Comparable<MapFileInfo> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("MapFileInfo");
 
   private static final org.apache.thrift.protocol.TField ESTIMATED_SIZE_FIELD_DESC = new org.apache.thrift.protocol.TField("estimatedSize", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public long estimatedSize; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     ESTIMATED_SIZE((short)1, "estimatedSize");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/MultiScanResult.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/MultiScanResult.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/MultiScanResult.java
index d7c0374..0140a68 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/MultiScanResult.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/MultiScanResult.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class MultiScanResult implements org.apache.thrift.TBase<MultiScanResult, MultiScanResult._Fields>, java.io.Serializable, Cloneable, Comparable<MultiScanResult> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class MultiScanResult implements org.apache.thrift.TBase<MultiScanResult, MultiScanResult._Fields>, java.io.Serializable, Cloneable, Comparable<MultiScanResult> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("MultiScanResult");
 
   private static final org.apache.thrift.protocol.TField RESULTS_FIELD_DESC = new org.apache.thrift.protocol.TField("results", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -74,7 +74,7 @@ import org.slf4j.LoggerFactory;
   public boolean more; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     RESULTS((short)1, "results"),
     FAILURES((short)2, "failures"),
     FULL_SCANS((short)3, "fullScans"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/ScanResult.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/ScanResult.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/ScanResult.java
index ce418a6..b936d2b 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/ScanResult.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/ScanResult.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ScanResult implements org.apache.thrift.TBase<ScanResult, ScanResult._Fields>, java.io.Serializable, Cloneable, Comparable<ScanResult> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ScanResult implements org.apache.thrift.TBase<ScanResult, ScanResult._Fields>, java.io.Serializable, Cloneable, Comparable<ScanResult> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ScanResult");
 
   private static final org.apache.thrift.protocol.TField RESULTS_FIELD_DESC = new org.apache.thrift.protocol.TField("results", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -64,7 +64,7 @@ import org.slf4j.LoggerFactory;
   public boolean more; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     RESULTS((short)1, "results"),
     MORE((short)2, "more");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/TCMResult.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/TCMResult.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/TCMResult.java
index 598bd48..7c60cd1 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/TCMResult.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/TCMResult.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TCMResult implements org.apache.thrift.TBase<TCMResult, TCMResult._Fields>, java.io.Serializable, Cloneable, Comparable<TCMResult> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TCMResult implements org.apache.thrift.TBase<TCMResult, TCMResult._Fields>, java.io.Serializable, Cloneable, Comparable<TCMResult> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TCMResult");
 
   private static final org.apache.thrift.protocol.TField CMID_FIELD_DESC = new org.apache.thrift.protocol.TField("cmid", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -68,7 +68,7 @@ import org.slf4j.LoggerFactory;
   public TCMStatus status; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     CMID((short)1, "cmid"),
     /**
      * 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/TCMStatus.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/TCMStatus.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/TCMStatus.java
index ee4592c..993e9e2 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/TCMStatus.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/TCMStatus.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum TCMStatus implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum TCMStatus implements org.apache.thrift.TEnum {
   ACCEPTED(0),
   REJECTED(1),
   VIOLATED(2),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/TColumn.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/TColumn.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/TColumn.java
index 125cece..127f7c6 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/TColumn.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/TColumn.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TColumn implements org.apache.thrift.TBase<TColumn, TColumn._Fields>, java.io.Serializable, Cloneable, Comparable<TColumn> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TColumn implements org.apache.thrift.TBase<TColumn, TColumn._Fields>, java.io.Serializable, Cloneable, Comparable<TColumn> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TColumn");
 
   private static final org.apache.thrift.protocol.TField COLUMN_FAMILY_FIELD_DESC = new org.apache.thrift.protocol.TField("columnFamily", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -66,7 +66,7 @@ import org.slf4j.LoggerFactory;
   public ByteBuffer columnVisibility; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     COLUMN_FAMILY((short)1, "columnFamily"),
     COLUMN_QUALIFIER((short)2, "columnQualifier"),
     COLUMN_VISIBILITY((short)3, "columnVisibility");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/TCondition.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/TCondition.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/TCondition.java
index 9fc3968..a4ae6df 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/TCondition.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/TCondition.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TCondition implements org.apache.thrift.TBase<TCondition, TCondition._Fields>, java.io.Serializable, Cloneable, Comparable<TCondition> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TCondition implements org.apache.thrift.TBase<TCondition, TCondition._Fields>, java.io.Serializable, Cloneable, Comparable<TCondition> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TCondition");
 
   private static final org.apache.thrift.protocol.TField CF_FIELD_DESC = new org.apache.thrift.protocol.TField("cf", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -74,7 +74,7 @@ import org.slf4j.LoggerFactory;
   public ByteBuffer iterators; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     CF((short)1, "cf"),
     CQ((short)2, "cq"),
     CV((short)3, "cv"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/TConditionalMutation.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/TConditionalMutation.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/TConditionalMutation.java
index 3d49c45..8c9f0a6 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/TConditionalMutation.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/TConditionalMutation.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TConditionalMutation implements org.apache.thrift.TBase<TConditionalMutation, TConditionalMutation._Fields>, java.io.Serializable, Cloneable, Comparable<TConditionalMutation> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TConditionalMutation implements org.apache.thrift.TBase<TConditionalMutation, TConditionalMutation._Fields>, java.io.Serializable, Cloneable, Comparable<TConditionalMutation> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TConditionalMutation");
 
   private static final org.apache.thrift.protocol.TField CONDITIONS_FIELD_DESC = new org.apache.thrift.protocol.TField("conditions", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -66,7 +66,7 @@ import org.slf4j.LoggerFactory;
   public long id; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     CONDITIONS((short)1, "conditions"),
     MUTATION((short)2, "mutation"),
     ID((short)3, "id");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/TConditionalSession.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/TConditionalSession.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/TConditionalSession.java
index 646dbdb..eb08623 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/TConditionalSession.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/TConditionalSession.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TConditionalSession implements org.apache.thrift.TBase<TConditionalSession, TConditionalSession._Fields>, java.io.Serializable, Cloneable, Comparable<TConditionalSession> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TConditionalSession implements org.apache.thrift.TBase<TConditionalSession, TConditionalSession._Fields>, java.io.Serializable, Cloneable, Comparable<TConditionalSession> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TConditionalSession");
 
   private static final org.apache.thrift.protocol.TField SESSION_ID_FIELD_DESC = new org.apache.thrift.protocol.TField("sessionId", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -66,7 +66,7 @@ import org.slf4j.LoggerFactory;
   public long ttl; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     SESSION_ID((short)1, "sessionId"),
     TSERVER_LOCK((short)2, "tserverLock"),
     TTL((short)3, "ttl");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/TConstraintViolationSummary.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/TConstraintViolationSummary.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/TConstraintViolationSummary.java
index d841eff..1dc51e3 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/TConstraintViolationSummary.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/TConstraintViolationSummary.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TConstraintViolationSummary implements org.apache.thrift.TBase<TConstraintViolationSummary, TConstraintViolationSummary._Fields>, java.io.Serializable, Cloneable, Comparable<TConstraintViolationSummary> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TConstraintViolationSummary implements org.apache.thrift.TBase<TConstraintViolationSummary, TConstraintViolationSummary._Fields>, java.io.Serializable, Cloneable, Comparable<TConstraintViolationSummary> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TConstraintViolationSummary");
 
   private static final org.apache.thrift.protocol.TField CONSTRAIN_CLASS_FIELD_DESC = new org.apache.thrift.protocol.TField("constrainClass", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -68,7 +68,7 @@ import org.slf4j.LoggerFactory;
   public long numberOfViolatingMutations; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     CONSTRAIN_CLASS((short)1, "constrainClass"),
     VIOLATION_CODE((short)2, "violationCode"),
     VIOLATION_DESCRIPTION((short)3, "violationDescription"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/TKey.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/TKey.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/TKey.java
index 4f05c66..2b81651 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/TKey.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/TKey.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TKey implements org.apache.thrift.TBase<TKey, TKey._Fields>, java.io.Serializable, Cloneable, Comparable<TKey> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TKey implements org.apache.thrift.TBase<TKey, TKey._Fields>, java.io.Serializable, Cloneable, Comparable<TKey> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TKey");
 
   private static final org.apache.thrift.protocol.TField ROW_FIELD_DESC = new org.apache.thrift.protocol.TField("row", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -70,7 +70,7 @@ import org.slf4j.LoggerFactory;
   public long timestamp; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     ROW((short)1, "row"),
     COL_FAMILY((short)2, "colFamily"),
     COL_QUALIFIER((short)3, "colQualifier"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/TKeyExtent.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/TKeyExtent.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/TKeyExtent.java
index b83fc1a..20f1fea 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/TKeyExtent.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/TKeyExtent.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TKeyExtent implements org.apache.thrift.TBase<TKeyExtent, TKeyExtent._Fields>, java.io.Serializable, Cloneable, Comparable<TKeyExtent> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TKeyExtent implements org.apache.thrift.TBase<TKeyExtent, TKeyExtent._Fields>, java.io.Serializable, Cloneable, Comparable<TKeyExtent> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TKeyExtent");
 
   private static final org.apache.thrift.protocol.TField TABLE_FIELD_DESC = new org.apache.thrift.protocol.TField("table", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -66,7 +66,7 @@ import org.slf4j.LoggerFactory;
   public ByteBuffer prevEndRow; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     TABLE((short)1, "table"),
     END_ROW((short)2, "endRow"),
     PREV_END_ROW((short)3, "prevEndRow");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/TKeyValue.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/TKeyValue.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/TKeyValue.java
index 4c47c69..75161b0 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/TKeyValue.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/TKeyValue.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TKeyValue implements org.apache.thrift.TBase<TKeyValue, TKeyValue._Fields>, java.io.Serializable, Cloneable, Comparable<TKeyValue> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TKeyValue implements org.apache.thrift.TBase<TKeyValue, TKeyValue._Fields>, java.io.Serializable, Cloneable, Comparable<TKeyValue> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TKeyValue");
 
   private static final org.apache.thrift.protocol.TField KEY_FIELD_DESC = new org.apache.thrift.protocol.TField("key", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -64,7 +64,7 @@ import org.slf4j.LoggerFactory;
   public ByteBuffer value; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     KEY((short)1, "key"),
     VALUE((short)2, "value");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/TMutation.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/TMutation.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/TMutation.java
index 1e00047..ecaf87c 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/TMutation.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/TMutation.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TMutation implements org.apache.thrift.TBase<TMutation, TMutation._Fields>, java.io.Serializable, Cloneable, Comparable<TMutation> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TMutation implements org.apache.thrift.TBase<TMutation, TMutation._Fields>, java.io.Serializable, Cloneable, Comparable<TMutation> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TMutation");
 
   private static final org.apache.thrift.protocol.TField ROW_FIELD_DESC = new org.apache.thrift.protocol.TField("row", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -68,7 +68,7 @@ import org.slf4j.LoggerFactory;
   public int entries; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     ROW((short)1, "row"),
     DATA((short)2, "data"),
     VALUES((short)3, "values"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/TRange.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/TRange.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/TRange.java
index 58e805f..0ad791c 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/TRange.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/TRange.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TRange implements org.apache.thrift.TBase<TRange, TRange._Fields>, java.io.Serializable, Cloneable, Comparable<TRange> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TRange implements org.apache.thrift.TBase<TRange, TRange._Fields>, java.io.Serializable, Cloneable, Comparable<TRange> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TRange");
 
   private static final org.apache.thrift.protocol.TField START_FIELD_DESC = new org.apache.thrift.protocol.TField("start", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -72,7 +72,7 @@ import org.slf4j.LoggerFactory;
   public boolean infiniteStopKey; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     START((short)1, "start"),
     STOP((short)2, "stop"),
     START_KEY_INCLUSIVE((short)3, "startKeyInclusive"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/UpdateErrors.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/UpdateErrors.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/UpdateErrors.java
index 55a0602..f2b53ad 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/UpdateErrors.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/UpdateErrors.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class UpdateErrors implements org.apache.thrift.TBase<UpdateErrors, UpdateErrors._Fields>, java.io.Serializable, Cloneable, Comparable<UpdateErrors> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class UpdateErrors implements org.apache.thrift.TBase<UpdateErrors, UpdateErrors._Fields>, java.io.Serializable, Cloneable, Comparable<UpdateErrors> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("UpdateErrors");
 
   private static final org.apache.thrift.protocol.TField FAILED_EXTENTS_FIELD_DESC = new org.apache.thrift.protocol.TField("failedExtents", org.apache.thrift.protocol.TType.MAP, (short)1);
@@ -66,7 +66,7 @@ import org.slf4j.LoggerFactory;
   public Map<TKeyExtent,org.apache.accumulo.core.client.impl.thrift.SecurityErrorCode> authorizationFailures; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     FAILED_EXTENTS((short)1, "failedExtents"),
     VIOLATION_SUMMARIES((short)2, "violationSummaries"),
     AUTHORIZATION_FAILURES((short)3, "authorizationFailures");


[20/25] accumulo git commit: ACCUMULO-3759 More build warnings on Java 8

Posted by ct...@apache.org.
http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TabletClientService.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TabletClientService.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TabletClientService.java
index 2ba7674..3384e00 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TabletClientService.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TabletClientService.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TabletClientService {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TabletClientService {
 
   public interface Iface extends org.apache.accumulo.core.client.impl.thrift.ClientService.Iface {
 
@@ -4336,7 +4336,7 @@ import org.slf4j.LoggerFactory;
     public long readaheadThreshold; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)11, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       EXTENT((short)2, "extent"),
@@ -6034,7 +6034,7 @@ import org.slf4j.LoggerFactory;
     public TooManyFilesException tmfe; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec"),
       NSTE((short)2, "nste"),
@@ -6695,7 +6695,7 @@ import org.slf4j.LoggerFactory;
     public long scanID; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       SCAN_ID((short)1, "scanID");
 
@@ -7156,7 +7156,7 @@ import org.slf4j.LoggerFactory;
     public TooManyFilesException tmfe; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       NSSI((short)1, "nssi"),
       NSTE((short)2, "nste"),
@@ -7817,7 +7817,7 @@ import org.slf4j.LoggerFactory;
     public long scanID; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       SCAN_ID((short)1, "scanID");
 
@@ -8286,7 +8286,7 @@ import org.slf4j.LoggerFactory;
     public boolean waitForWrites; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)8, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       BATCH((short)2, "batch"),
@@ -9681,7 +9681,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -10142,7 +10142,7 @@ import org.slf4j.LoggerFactory;
     public long scanID; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       SCAN_ID((short)1, "scanID");
 
@@ -10599,7 +10599,7 @@ import org.slf4j.LoggerFactory;
     public NoSuchScanIDException nssi; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       NSSI((short)1, "nssi");
 
@@ -11060,7 +11060,7 @@ import org.slf4j.LoggerFactory;
     public long scanID; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       SCAN_ID((short)1, "scanID");
 
@@ -11515,7 +11515,7 @@ import org.slf4j.LoggerFactory;
     public NoSuchScanIDException nssi; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       NSSI((short)1, "nssi");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -11873,7 +11873,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.security.thrift.TCredentials credentials; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       CREDENTIALS((short)1, "credentials");
 
@@ -12337,7 +12337,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -12797,7 +12797,7 @@ import org.slf4j.LoggerFactory;
     public List<org.apache.accumulo.core.data.thrift.TMutation> mutations; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       UPDATE_ID((short)2, "updateID"),
       KEY_EXTENT((short)3, "keyExtent"),
@@ -13509,7 +13509,7 @@ import org.slf4j.LoggerFactory;
     public long updateID; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       UPDATE_ID((short)1, "updateID");
 
@@ -13966,7 +13966,7 @@ import org.slf4j.LoggerFactory;
     public NoSuchScanIDException nssi; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       NSSI((short)1, "nssi");
 
@@ -14431,7 +14431,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.data.thrift.TMutation mutation; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)4, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       KEY_EXTENT((short)2, "keyExtent"),
@@ -15103,7 +15103,7 @@ import org.slf4j.LoggerFactory;
     public ConstraintViolationException cve; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec"),
       NSTE((short)2, "nste"),
       CVE((short)3, "cve");
@@ -15665,7 +15665,7 @@ import org.slf4j.LoggerFactory;
     public String tableID; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)2, "credentials"),
       AUTHORIZATIONS((short)3, "authorizations"),
@@ -16374,7 +16374,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -16839,7 +16839,7 @@ import org.slf4j.LoggerFactory;
     public List<String> symbols; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       SESS_ID((short)2, "sessID"),
       MUTATIONS((short)3, "mutations"),
@@ -17626,7 +17626,7 @@ import org.slf4j.LoggerFactory;
     public NoSuchScanIDException nssi; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       NSSI((short)1, "nssi");
 
@@ -18136,7 +18136,7 @@ import org.slf4j.LoggerFactory;
     public long sessID; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       SESS_ID((short)2, "sessID");
 
@@ -18589,7 +18589,7 @@ import org.slf4j.LoggerFactory;
 
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
 ;
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -18839,7 +18839,7 @@ import org.slf4j.LoggerFactory;
     public long sessID; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       SESS_ID((short)2, "sessID");
 
@@ -19302,7 +19302,7 @@ import org.slf4j.LoggerFactory;
     public boolean setTime; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       TID((short)4, "tid"),
@@ -20143,7 +20143,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -20657,7 +20657,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer splitPoint; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)4, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       EXTENT((short)2, "extent"),
@@ -21333,7 +21333,7 @@ import org.slf4j.LoggerFactory;
     public NotServingTabletException nste; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec"),
       NSTE((short)2, "nste");
 
@@ -21795,7 +21795,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.data.thrift.TKeyExtent extent; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)5, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       LOCK((short)4, "lock"),
@@ -22466,7 +22466,7 @@ import org.slf4j.LoggerFactory;
     public boolean save; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)5, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       LOCK((short)4, "lock"),
@@ -23235,7 +23235,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer endRow; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)4, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       LOCK((short)3, "lock"),
@@ -24117,7 +24117,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.data.thrift.TKeyExtent extent; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)2, "credentials"),
       LOCK((short)3, "lock"),
@@ -24786,7 +24786,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.data.thrift.TKeyExtent extent; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)2, "credentials"),
       LOCK((short)3, "lock"),
@@ -25459,7 +25459,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer endRow; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)2, "credentials"),
       LOCK((short)3, "lock"),
@@ -26337,7 +26337,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.security.thrift.TCredentials credentials; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)1, "credentials");
 
@@ -26801,7 +26801,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -27264,7 +27264,7 @@ import org.slf4j.LoggerFactory;
     public String tableId; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       TABLE_ID((short)2, "tableId");
@@ -27826,7 +27826,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -28336,7 +28336,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.security.thrift.TCredentials credentials; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       CREDENTIALS((short)1, "credentials");
 
@@ -28800,7 +28800,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -29263,7 +29263,7 @@ import org.slf4j.LoggerFactory;
     public String lock; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       LOCK((short)2, "lock");
@@ -29823,7 +29823,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -30183,7 +30183,7 @@ import org.slf4j.LoggerFactory;
     public String lock; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       LOCK((short)2, "lock");
@@ -30745,7 +30745,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.security.thrift.TCredentials credentials; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       CREDENTIALS((short)1, "credentials");
 
@@ -31209,7 +31209,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -31719,7 +31719,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.security.thrift.TCredentials credentials; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       CREDENTIALS((short)1, "credentials");
 
@@ -32183,7 +32183,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -32695,7 +32695,7 @@ import org.slf4j.LoggerFactory;
     public List<String> filenames; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)2, "credentials"),
       FILENAMES((short)3, "filenames");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TabletStats.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TabletStats.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TabletStats.java
index 8989fe5..310d3b6 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TabletStats.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TabletStats.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TabletStats implements org.apache.thrift.TBase<TabletStats, TabletStats._Fields>, java.io.Serializable, Cloneable, Comparable<TabletStats> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TabletStats implements org.apache.thrift.TBase<TabletStats, TabletStats._Fields>, java.io.Serializable, Cloneable, Comparable<TabletStats> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TabletStats");
 
   private static final org.apache.thrift.protocol.TField EXTENT_FIELD_DESC = new org.apache.thrift.protocol.TField("extent", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -76,7 +76,7 @@ import org.slf4j.LoggerFactory;
   public long splitCreationTime; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     EXTENT((short)1, "extent"),
     MAJORS((short)2, "majors"),
     MINORS((short)3, "minors"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TooManyFilesException.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TooManyFilesException.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TooManyFilesException.java
index cc4c3e8..203597a 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TooManyFilesException.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TooManyFilesException.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TooManyFilesException extends TException implements org.apache.thrift.TBase<TooManyFilesException, TooManyFilesException._Fields>, java.io.Serializable, Cloneable, Comparable<TooManyFilesException> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TooManyFilesException extends TException implements org.apache.thrift.TBase<TooManyFilesException, TooManyFilesException._Fields>, java.io.Serializable, Cloneable, Comparable<TooManyFilesException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TooManyFilesException");
 
   private static final org.apache.thrift.protocol.TField EXTENT_FIELD_DESC = new org.apache.thrift.protocol.TField("extent", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public org.apache.accumulo.core.data.thrift.TKeyExtent extent; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     EXTENT((short)1, "extent");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/scripts/generate-thrift.sh
----------------------------------------------------------------------
diff --git a/core/src/main/scripts/generate-thrift.sh b/core/src/main/scripts/generate-thrift.sh
index ee5bb8e..8c2a623 100755
--- a/core/src/main/scripts/generate-thrift.sh
+++ b/core/src/main/scripts/generate-thrift.sh
@@ -26,23 +26,23 @@
 #   INCLUDED_MODULES should be an array that includes other Maven modules with src/main/thrift directories
 #   Use INCLUDED_MODULES=(-) in calling scripts that require no other modules
 # ========================================================================================================================
-[ -z $REQUIRED_THRIFT_VERSION ] && REQUIRED_THRIFT_VERSION='0.9.1'
-[ -z $INCLUDED_MODULES ]        && INCLUDED_MODULES=(../trace)
-[ -z $BASE_OUTPUT_PACKAGE ]     && BASE_OUTPUT_PACKAGE='org.apache.accumulo.core'
-[ -z $PACKAGES_TO_GENERATE ]    && PACKAGES_TO_GENERATE=(gc master tabletserver security client.impl data)
-[ -z $BUILD_DIR ]               && BUILD_DIR='target'
-[ -z $LANGUAGES_TO_GENERATE ]   && LANGUAGES_TO_GENERATE=(java)
-[ -z $FINAL_DIR ]               && FINAL_DIR='src/main'
+[[ -z $REQUIRED_THRIFT_VERSION ]] && REQUIRED_THRIFT_VERSION='0.9.1'
+[[ -z $INCLUDED_MODULES ]]        && INCLUDED_MODULES=(../trace)
+[[ -z $BASE_OUTPUT_PACKAGE ]]     && BASE_OUTPUT_PACKAGE='org.apache.accumulo.core'
+[[ -z $PACKAGES_TO_GENERATE ]]    && PACKAGES_TO_GENERATE=(gc master tabletserver security client.impl data)
+[[ -z $BUILD_DIR ]]               && BUILD_DIR='target'
+[[ -z $LANGUAGES_TO_GENERATE ]]   && LANGUAGES_TO_GENERATE=(java)
+[[ -z $FINAL_DIR ]]               && FINAL_DIR='src/main'
 # ========================================================================================================================
 
 fail() {
-  echo $@
+  echo "$@"
   exit 1
 }
 
 # Test to see if we have thrift installed
-VERSION=$(thrift -version 2>/dev/null | grep -F "${REQUIRED_THRIFT_VERSION}" |  wc -l)
-if [ "$VERSION" -ne 1 ] ; then 
+VERSION=$(thrift -version 2>/dev/null | grep -F "${REQUIRED_THRIFT_VERSION}" |  wc -l | sed -e 's/^ *//' -e 's/ *$//')
+if [[ "${VERSION}" != '1' ]] ; then
   # Nope: bail
   echo "****************************************************"
   echo "*** thrift is not available"
@@ -65,15 +65,17 @@ THRIFT_ARGS="${THRIFT_ARGS} -o $BUILD_DIR"
 mkdir -p $BUILD_DIR
 rm -rf $BUILD_DIR/gen-java
 for f in src/main/thrift/*.thrift; do
-  thrift ${THRIFT_ARGS} --gen java $f || fail unable to generate java thrift classes
-  thrift ${THRIFT_ARGS} --gen py $f || fail unable to generate python thrift classes
-  thrift ${THRIFT_ARGS} --gen rb $f || fail unable to generate ruby thrift classes
-  thrift ${THRIFT_ARGS} --gen cpp $f || fail unable to generate cpp thrift classes
+  thrift ${THRIFT_ARGS} --gen java "$f" || fail unable to generate java thrift classes
+  thrift ${THRIFT_ARGS} --gen py "$f" || fail unable to generate python thrift classes
+  thrift ${THRIFT_ARGS} --gen rb "$f" || fail unable to generate ruby thrift classes
+  thrift ${THRIFT_ARGS} --gen cpp "$f" || fail unable to generate cpp thrift classes
 done
 
 # For all generated thrift code, suppress all warnings and add the LICENSE header
-find $BUILD_DIR/gen-java -name '*.java' -print0 | xargs -0 sed -i.orig -e 's/public class /@SuppressWarnings("all") public class /'
-find $BUILD_DIR/gen-java -name '*.java' -print0 | xargs -0 sed -i.orig -e 's/public enum /@SuppressWarnings("all") public enum /'
+cs='@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"})'
+es='@SuppressWarnings({"unused"})'
+find $BUILD_DIR/gen-java -name '*.java' -print0 | xargs -0 sed -i.orig -e 's/\(public class [A-Z]\)/'"$cs"' \1/'
+find $BUILD_DIR/gen-java -name '*.java' -print0 | xargs -0 sed -i.orig -e 's/\(public enum [A-Z]\)/'"$es"' \1/'
 
 for lang in "${LANGUAGES_TO_GENERATE[@]}"; do
   case $lang in
@@ -109,10 +111,10 @@ for lang in "${LANGUAGES_TO_GENERATE[@]}"; do
       continue
       ;;
   esac
-  
-  for file in ${FILE_SUFFIX[@]}; do
+
+  for file in "${FILE_SUFFIX[@]}"; do
     for f in $(find $BUILD_DIR/gen-$lang -name "*$file"); do
-      cat - $f >${f}-with-license <<EOF
+      cat - "$f" > "${f}-with-license" <<EOF
 ${PREFIX}${LINE_NOTATION} Licensed to the Apache Software Foundation (ASF) under one or more
 ${LINE_NOTATION} contributor license agreements.  See the NOTICE file distributed with
 ${LINE_NOTATION} this work for additional information regarding copyright ownership.
@@ -135,7 +137,7 @@ done
 # For every generated java file, compare it with the version-controlled one, and copy the ones that have changed into place
 for d in "${PACKAGES_TO_GENERATE[@]}"; do
   for lang in "${LANGUAGES_TO_GENERATE[@]}"; do
-    case $lang in
+    case "$lang" in
       cpp)
         SDIR="${BUILD_DIR}/gen-$lang/"
         DDIR="${FINAL_DIR}/cpp/"
@@ -161,11 +163,11 @@ for d in "${PACKAGES_TO_GENERATE[@]}"; do
         ;;
     esac
     mkdir -p "$DDIR"
-    for file in ${FILE_SUFFIX[@]}; do
-      for f in `find $SDIR -name *$file`; do
-        DEST="$DDIR/`basename $f`"
+    for file in "${FILE_SUFFIX[@]}"; do
+      for f in $(find $SDIR -name *$file); do
+        DEST="$DDIR/$(basename $f)"
         if ! cmp -s "${f}-with-license" "${DEST}" ; then
-          echo cp -f "${f}-with-license" "${DEST}" 
+          echo cp -f "${f}-with-license" "${DEST}"
           cp -f "${f}-with-license" "${DEST}" || fail unable to copy files to java workspace
         fi
       done

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index 3389795..9249a5b 100644
--- a/pom.xml
+++ b/pom.xml
@@ -118,6 +118,8 @@
     <accumulo.release.version>${project.version}</accumulo.release.version>
     <!-- bouncycastle version for test dependencies -->
     <bouncycastle.version>1.50</bouncycastle.version>
+    <!-- findbugs-maven-plugin won't work on jdk8 or later; set to 3.0.0 or newer -->
+    <findbugs.version>2.5.5</findbugs.version>
     <!-- surefire/failsafe plugin option -->
     <forkCount>1</forkCount>
     <!-- overwritten in profiles hadoop-1 or hadoop-2 -->
@@ -499,7 +501,7 @@
         <plugin>
           <groupId>org.codehaus.mojo</groupId>
           <artifactId>findbugs-maven-plugin</artifactId>
-          <version>2.5.5</version>
+          <version>${findbugs.version}</version>
           <configuration>
             <xmlOutput>true</xmlOutput>
             <effort>Max</effort>
@@ -1141,7 +1143,7 @@
       <plugin>
         <groupId>org.codehaus.mojo</groupId>
         <artifactId>findbugs-maven-plugin</artifactId>
-        <version>2.5.3</version>
+        <version>${findbugs.version}</version>
         <configuration>
           <excludeFilterFile>contrib/findbugs-exclude.xml</excludeFilterFile>
           <findbugsXmlOutput>true</findbugsXmlOutput>

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloException.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloException.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloException.java
index 0be034c..724a92e 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloException.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloException.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class AccumuloException extends TException implements org.apache.thrift.TBase<AccumuloException, AccumuloException._Fields>, java.io.Serializable, Cloneable, Comparable<AccumuloException> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class AccumuloException extends TException implements org.apache.thrift.TBase<AccumuloException, AccumuloException._Fields>, java.io.Serializable, Cloneable, Comparable<AccumuloException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("AccumuloException");
 
   private static final org.apache.thrift.protocol.TField MSG_FIELD_DESC = new org.apache.thrift.protocol.TField("msg", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public String msg; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     MSG((short)1, "msg");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();


[13/25] accumulo git commit: ACCUMULO-3759 More build warnings on Java 8

Posted by ct...@apache.org.
http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Condition.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Condition.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Condition.java
index 8dd28cf..c4b3c07 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Condition.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Condition.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class Condition implements org.apache.thrift.TBase<Condition, Condition._Fields>, java.io.Serializable, Cloneable, Comparable<Condition> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class Condition implements org.apache.thrift.TBase<Condition, Condition._Fields>, java.io.Serializable, Cloneable, Comparable<Condition> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("Condition");
 
   private static final org.apache.thrift.protocol.TField COLUMN_FIELD_DESC = new org.apache.thrift.protocol.TField("column", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -68,7 +68,7 @@ import org.slf4j.LoggerFactory;
   public List<IteratorSetting> iterators; // optional
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     COLUMN((short)1, "column"),
     TIMESTAMP((short)2, "timestamp"),
     VALUE((short)3, "value"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalStatus.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalStatus.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalStatus.java
index 55f0e62..515c416 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalStatus.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalStatus.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum ConditionalStatus implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum ConditionalStatus implements org.apache.thrift.TEnum {
   ACCEPTED(0),
   REJECTED(1),
   VIOLATED(2),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalUpdates.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalUpdates.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalUpdates.java
index 71806fe..551e996 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalUpdates.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalUpdates.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ConditionalUpdates implements org.apache.thrift.TBase<ConditionalUpdates, ConditionalUpdates._Fields>, java.io.Serializable, Cloneable, Comparable<ConditionalUpdates> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ConditionalUpdates implements org.apache.thrift.TBase<ConditionalUpdates, ConditionalUpdates._Fields>, java.io.Serializable, Cloneable, Comparable<ConditionalUpdates> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ConditionalUpdates");
 
   private static final org.apache.thrift.protocol.TField CONDITIONS_FIELD_DESC = new org.apache.thrift.protocol.TField("conditions", org.apache.thrift.protocol.TType.LIST, (short)2);
@@ -64,7 +64,7 @@ import org.slf4j.LoggerFactory;
   public List<ColumnUpdate> updates; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     CONDITIONS((short)2, "conditions"),
     UPDATES((short)3, "updates");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalWriterOptions.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalWriterOptions.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalWriterOptions.java
index bb4ad51..99c5172 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalWriterOptions.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalWriterOptions.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ConditionalWriterOptions implements org.apache.thrift.TBase<ConditionalWriterOptions, ConditionalWriterOptions._Fields>, java.io.Serializable, Cloneable, Comparable<ConditionalWriterOptions> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ConditionalWriterOptions implements org.apache.thrift.TBase<ConditionalWriterOptions, ConditionalWriterOptions._Fields>, java.io.Serializable, Cloneable, Comparable<ConditionalWriterOptions> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ConditionalWriterOptions");
 
   private static final org.apache.thrift.protocol.TField MAX_MEMORY_FIELD_DESC = new org.apache.thrift.protocol.TField("maxMemory", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -68,7 +68,7 @@ import org.slf4j.LoggerFactory;
   public Set<ByteBuffer> authorizations; // optional
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     MAX_MEMORY((short)1, "maxMemory"),
     TIMEOUT_MS((short)2, "timeoutMs"),
     THREADS((short)3, "threads"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/DiskUsage.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/DiskUsage.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/DiskUsage.java
index 36080ed..82a886d 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/DiskUsage.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/DiskUsage.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class DiskUsage implements org.apache.thrift.TBase<DiskUsage, DiskUsage._Fields>, java.io.Serializable, Cloneable, Comparable<DiskUsage> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class DiskUsage implements org.apache.thrift.TBase<DiskUsage, DiskUsage._Fields>, java.io.Serializable, Cloneable, Comparable<DiskUsage> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("DiskUsage");
 
   private static final org.apache.thrift.protocol.TField TABLES_FIELD_DESC = new org.apache.thrift.protocol.TField("tables", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -64,7 +64,7 @@ import org.slf4j.LoggerFactory;
   public long usage; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     TABLES((short)1, "tables"),
     USAGE((short)2, "usage");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/IteratorScope.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/IteratorScope.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/IteratorScope.java
index bafd525..0fc8de8 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/IteratorScope.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/IteratorScope.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum IteratorScope implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum IteratorScope implements org.apache.thrift.TEnum {
   MINC(0),
   MAJC(1),
   SCAN(2);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/IteratorSetting.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/IteratorSetting.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/IteratorSetting.java
index 1956b9a..eabc686 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/IteratorSetting.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/IteratorSetting.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class IteratorSetting implements org.apache.thrift.TBase<IteratorSetting, IteratorSetting._Fields>, java.io.Serializable, Cloneable, Comparable<IteratorSetting> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class IteratorSetting implements org.apache.thrift.TBase<IteratorSetting, IteratorSetting._Fields>, java.io.Serializable, Cloneable, Comparable<IteratorSetting> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("IteratorSetting");
 
   private static final org.apache.thrift.protocol.TField PRIORITY_FIELD_DESC = new org.apache.thrift.protocol.TField("priority", org.apache.thrift.protocol.TType.I32, (short)1);
@@ -68,7 +68,7 @@ import org.slf4j.LoggerFactory;
   public Map<String,String> properties; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     PRIORITY((short)1, "priority"),
     NAME((short)2, "name"),
     ITERATOR_CLASS((short)3, "iteratorClass"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Key.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Key.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Key.java
index ecba9d1..6984cf2 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Key.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Key.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class Key implements org.apache.thrift.TBase<Key, Key._Fields>, java.io.Serializable, Cloneable, Comparable<Key> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class Key implements org.apache.thrift.TBase<Key, Key._Fields>, java.io.Serializable, Cloneable, Comparable<Key> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("Key");
 
   private static final org.apache.thrift.protocol.TField ROW_FIELD_DESC = new org.apache.thrift.protocol.TField("row", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -70,7 +70,7 @@ import org.slf4j.LoggerFactory;
   public long timestamp; // optional
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     ROW((short)1, "row"),
     COL_FAMILY((short)2, "colFamily"),
     COL_QUALIFIER((short)3, "colQualifier"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyExtent.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyExtent.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyExtent.java
index f9c9e4c..1136284 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyExtent.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyExtent.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class KeyExtent implements org.apache.thrift.TBase<KeyExtent, KeyExtent._Fields>, java.io.Serializable, Cloneable, Comparable<KeyExtent> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class KeyExtent implements org.apache.thrift.TBase<KeyExtent, KeyExtent._Fields>, java.io.Serializable, Cloneable, Comparable<KeyExtent> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("KeyExtent");
 
   private static final org.apache.thrift.protocol.TField TABLE_ID_FIELD_DESC = new org.apache.thrift.protocol.TField("tableId", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -66,7 +66,7 @@ import org.slf4j.LoggerFactory;
   public ByteBuffer prevEndRow; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     TABLE_ID((short)1, "tableId"),
     END_ROW((short)2, "endRow"),
     PREV_END_ROW((short)3, "prevEndRow");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyValue.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyValue.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyValue.java
index 52bfbd1..76d71b5 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyValue.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyValue.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class KeyValue implements org.apache.thrift.TBase<KeyValue, KeyValue._Fields>, java.io.Serializable, Cloneable, Comparable<KeyValue> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class KeyValue implements org.apache.thrift.TBase<KeyValue, KeyValue._Fields>, java.io.Serializable, Cloneable, Comparable<KeyValue> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("KeyValue");
 
   private static final org.apache.thrift.protocol.TField KEY_FIELD_DESC = new org.apache.thrift.protocol.TField("key", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -64,7 +64,7 @@ import org.slf4j.LoggerFactory;
   public ByteBuffer value; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     KEY((short)1, "key"),
     VALUE((short)2, "value");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyValueAndPeek.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyValueAndPeek.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyValueAndPeek.java
index 1993d01..88b0c3f 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyValueAndPeek.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyValueAndPeek.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class KeyValueAndPeek implements org.apache.thrift.TBase<KeyValueAndPeek, KeyValueAndPeek._Fields>, java.io.Serializable, Cloneable, Comparable<KeyValueAndPeek> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class KeyValueAndPeek implements org.apache.thrift.TBase<KeyValueAndPeek, KeyValueAndPeek._Fields>, java.io.Serializable, Cloneable, Comparable<KeyValueAndPeek> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("KeyValueAndPeek");
 
   private static final org.apache.thrift.protocol.TField KEY_VALUE_FIELD_DESC = new org.apache.thrift.protocol.TField("keyValue", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -64,7 +64,7 @@ import org.slf4j.LoggerFactory;
   public boolean hasNext; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     KEY_VALUE((short)1, "keyValue"),
     HAS_NEXT((short)2, "hasNext");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/MutationsRejectedException.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/MutationsRejectedException.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/MutationsRejectedException.java
index c0f8740..e5dfda1 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/MutationsRejectedException.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/MutationsRejectedException.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class MutationsRejectedException extends TException implements org.apache.thrift.TBase<MutationsRejectedException, MutationsRejectedException._Fields>, java.io.Serializable, Cloneable, Comparable<MutationsRejectedException> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class MutationsRejectedException extends TException implements org.apache.thrift.TBase<MutationsRejectedException, MutationsRejectedException._Fields>, java.io.Serializable, Cloneable, Comparable<MutationsRejectedException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("MutationsRejectedException");
 
   private static final org.apache.thrift.protocol.TField MSG_FIELD_DESC = new org.apache.thrift.protocol.TField("msg", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public String msg; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     MSG((short)1, "msg");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/NoMoreEntriesException.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/NoMoreEntriesException.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/NoMoreEntriesException.java
index b0a543a..d67bcd2 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/NoMoreEntriesException.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/NoMoreEntriesException.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class NoMoreEntriesException extends TException implements org.apache.thrift.TBase<NoMoreEntriesException, NoMoreEntriesException._Fields>, java.io.Serializable, Cloneable, Comparable<NoMoreEntriesException> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class NoMoreEntriesException extends TException implements org.apache.thrift.TBase<NoMoreEntriesException, NoMoreEntriesException._Fields>, java.io.Serializable, Cloneable, Comparable<NoMoreEntriesException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("NoMoreEntriesException");
 
   private static final org.apache.thrift.protocol.TField MSG_FIELD_DESC = new org.apache.thrift.protocol.TField("msg", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public String msg; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     MSG((short)1, "msg");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/PartialKey.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/PartialKey.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/PartialKey.java
index 1c9bfc4..2a0f269 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/PartialKey.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/PartialKey.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum PartialKey implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum PartialKey implements org.apache.thrift.TEnum {
   ROW(0),
   ROW_COLFAM(1),
   ROW_COLFAM_COLQUAL(2),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Range.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Range.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Range.java
index b1f505f..bc66c6b 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Range.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Range.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class Range implements org.apache.thrift.TBase<Range, Range._Fields>, java.io.Serializable, Cloneable, Comparable<Range> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class Range implements org.apache.thrift.TBase<Range, Range._Fields>, java.io.Serializable, Cloneable, Comparable<Range> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("Range");
 
   private static final org.apache.thrift.protocol.TField START_FIELD_DESC = new org.apache.thrift.protocol.TField("start", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -68,7 +68,7 @@ import org.slf4j.LoggerFactory;
   public boolean stopInclusive; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     START((short)1, "start"),
     START_INCLUSIVE((short)2, "startInclusive"),
     STOP((short)3, "stop"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanColumn.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanColumn.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanColumn.java
index 101d720..296c885 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanColumn.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanColumn.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ScanColumn implements org.apache.thrift.TBase<ScanColumn, ScanColumn._Fields>, java.io.Serializable, Cloneable, Comparable<ScanColumn> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ScanColumn implements org.apache.thrift.TBase<ScanColumn, ScanColumn._Fields>, java.io.Serializable, Cloneable, Comparable<ScanColumn> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ScanColumn");
 
   private static final org.apache.thrift.protocol.TField COL_FAMILY_FIELD_DESC = new org.apache.thrift.protocol.TField("colFamily", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -64,7 +64,7 @@ import org.slf4j.LoggerFactory;
   public ByteBuffer colQualifier; // optional
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     COL_FAMILY((short)1, "colFamily"),
     COL_QUALIFIER((short)2, "colQualifier");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanOptions.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanOptions.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanOptions.java
index 1e025ba..047daa0 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanOptions.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanOptions.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ScanOptions implements org.apache.thrift.TBase<ScanOptions, ScanOptions._Fields>, java.io.Serializable, Cloneable, Comparable<ScanOptions> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ScanOptions implements org.apache.thrift.TBase<ScanOptions, ScanOptions._Fields>, java.io.Serializable, Cloneable, Comparable<ScanOptions> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ScanOptions");
 
   private static final org.apache.thrift.protocol.TField AUTHORIZATIONS_FIELD_DESC = new org.apache.thrift.protocol.TField("authorizations", org.apache.thrift.protocol.TType.SET, (short)1);
@@ -70,7 +70,7 @@ import org.slf4j.LoggerFactory;
   public int bufferSize; // optional
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     AUTHORIZATIONS((short)1, "authorizations"),
     RANGE((short)2, "range"),
     COLUMNS((short)3, "columns"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanResult.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanResult.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanResult.java
index 02e1fe0..3775e7d 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanResult.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanResult.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ScanResult implements org.apache.thrift.TBase<ScanResult, ScanResult._Fields>, java.io.Serializable, Cloneable, Comparable<ScanResult> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ScanResult implements org.apache.thrift.TBase<ScanResult, ScanResult._Fields>, java.io.Serializable, Cloneable, Comparable<ScanResult> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ScanResult");
 
   private static final org.apache.thrift.protocol.TField RESULTS_FIELD_DESC = new org.apache.thrift.protocol.TField("results", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -64,7 +64,7 @@ import org.slf4j.LoggerFactory;
   public boolean more; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     RESULTS((short)1, "results"),
     MORE((short)2, "more");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanState.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanState.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanState.java
index 46608d1..127d147 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanState.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanState.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum ScanState implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum ScanState implements org.apache.thrift.TEnum {
   IDLE(0),
   RUNNING(1),
   QUEUED(2);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanType.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanType.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanType.java
index e153997..f417110 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanType.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanType.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum ScanType implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum ScanType implements org.apache.thrift.TEnum {
   SINGLE(0),
   BATCH(1);
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/SystemPermission.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/SystemPermission.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/SystemPermission.java
index 40e61d0..929b83a 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/SystemPermission.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/SystemPermission.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum SystemPermission implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum SystemPermission implements org.apache.thrift.TEnum {
   GRANT(0),
   CREATE_TABLE(1),
   DROP_TABLE(2),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TableExistsException.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TableExistsException.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TableExistsException.java
index 031de3a..9e3cf9c 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TableExistsException.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TableExistsException.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TableExistsException extends TException implements org.apache.thrift.TBase<TableExistsException, TableExistsException._Fields>, java.io.Serializable, Cloneable, Comparable<TableExistsException> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TableExistsException extends TException implements org.apache.thrift.TBase<TableExistsException, TableExistsException._Fields>, java.io.Serializable, Cloneable, Comparable<TableExistsException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TableExistsException");
 
   private static final org.apache.thrift.protocol.TField MSG_FIELD_DESC = new org.apache.thrift.protocol.TField("msg", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public String msg; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     MSG((short)1, "msg");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TableNotFoundException.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TableNotFoundException.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TableNotFoundException.java
index 6e8ec11..f12059b 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TableNotFoundException.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TableNotFoundException.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TableNotFoundException extends TException implements org.apache.thrift.TBase<TableNotFoundException, TableNotFoundException._Fields>, java.io.Serializable, Cloneable, Comparable<TableNotFoundException> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TableNotFoundException extends TException implements org.apache.thrift.TBase<TableNotFoundException, TableNotFoundException._Fields>, java.io.Serializable, Cloneable, Comparable<TableNotFoundException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TableNotFoundException");
 
   private static final org.apache.thrift.protocol.TField MSG_FIELD_DESC = new org.apache.thrift.protocol.TField("msg", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public String msg; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     MSG((short)1, "msg");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TablePermission.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TablePermission.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TablePermission.java
index f36d933..04882fa 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TablePermission.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TablePermission.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum TablePermission implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum TablePermission implements org.apache.thrift.TEnum {
   READ(2),
   WRITE(3),
   BULK_IMPORT(4),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TimeType.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TimeType.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TimeType.java
index b497ecc..32564e0 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TimeType.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TimeType.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum TimeType implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum TimeType implements org.apache.thrift.TEnum {
   LOGICAL(0),
   MILLIS(1);
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/UnknownScanner.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/UnknownScanner.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/UnknownScanner.java
index a324af8..f6a4b1e 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/UnknownScanner.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/UnknownScanner.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class UnknownScanner extends TException implements org.apache.thrift.TBase<UnknownScanner, UnknownScanner._Fields>, java.io.Serializable, Cloneable, Comparable<UnknownScanner> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class UnknownScanner extends TException implements org.apache.thrift.TBase<UnknownScanner, UnknownScanner._Fields>, java.io.Serializable, Cloneable, Comparable<UnknownScanner> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("UnknownScanner");
 
   private static final org.apache.thrift.protocol.TField MSG_FIELD_DESC = new org.apache.thrift.protocol.TField("msg", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public String msg; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     MSG((short)1, "msg");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/UnknownWriter.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/UnknownWriter.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/UnknownWriter.java
index 5b83ae5..661aa1b 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/UnknownWriter.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/UnknownWriter.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class UnknownWriter extends TException implements org.apache.thrift.TBase<UnknownWriter, UnknownWriter._Fields>, java.io.Serializable, Cloneable, Comparable<UnknownWriter> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class UnknownWriter extends TException implements org.apache.thrift.TBase<UnknownWriter, UnknownWriter._Fields>, java.io.Serializable, Cloneable, Comparable<UnknownWriter> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("UnknownWriter");
 
   private static final org.apache.thrift.protocol.TField MSG_FIELD_DESC = new org.apache.thrift.protocol.TField("msg", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public String msg; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     MSG((short)1, "msg");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/WriterOptions.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/WriterOptions.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/WriterOptions.java
index 5f000a8..a57b995 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/WriterOptions.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/WriterOptions.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class WriterOptions implements org.apache.thrift.TBase<WriterOptions, WriterOptions._Fields>, java.io.Serializable, Cloneable, Comparable<WriterOptions> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class WriterOptions implements org.apache.thrift.TBase<WriterOptions, WriterOptions._Fields>, java.io.Serializable, Cloneable, Comparable<WriterOptions> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("WriterOptions");
 
   private static final org.apache.thrift.protocol.TField MAX_MEMORY_FIELD_DESC = new org.apache.thrift.protocol.TField("maxMemory", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -68,7 +68,7 @@ import org.slf4j.LoggerFactory;
   public int threads; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     MAX_MEMORY((short)1, "maxMemory"),
     LATENCY_MS((short)2, "latencyMs"),
     TIMEOUT_MS((short)3, "timeoutMs"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/trace/src/main/java/org/apache/accumulo/trace/thrift/RemoteSpan.java
----------------------------------------------------------------------
diff --git a/trace/src/main/java/org/apache/accumulo/trace/thrift/RemoteSpan.java b/trace/src/main/java/org/apache/accumulo/trace/thrift/RemoteSpan.java
index 416ae17..ffd66c8 100644
--- a/trace/src/main/java/org/apache/accumulo/trace/thrift/RemoteSpan.java
+++ b/trace/src/main/java/org/apache/accumulo/trace/thrift/RemoteSpan.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class RemoteSpan implements org.apache.thrift.TBase<RemoteSpan, RemoteSpan._Fields>, java.io.Serializable, Cloneable, Comparable<RemoteSpan> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class RemoteSpan implements org.apache.thrift.TBase<RemoteSpan, RemoteSpan._Fields>, java.io.Serializable, Cloneable, Comparable<RemoteSpan> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("RemoteSpan");
 
   private static final org.apache.thrift.protocol.TField SENDER_FIELD_DESC = new org.apache.thrift.protocol.TField("sender", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -78,7 +78,7 @@ import org.slf4j.LoggerFactory;
   public Map<String,String> data; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     SENDER((short)1, "sender"),
     SVC((short)2, "svc"),
     TRACE_ID((short)3, "traceId"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/trace/src/main/java/org/apache/accumulo/trace/thrift/SpanReceiver.java
----------------------------------------------------------------------
diff --git a/trace/src/main/java/org/apache/accumulo/trace/thrift/SpanReceiver.java b/trace/src/main/java/org/apache/accumulo/trace/thrift/SpanReceiver.java
index 4fe4c38..19b260f 100644
--- a/trace/src/main/java/org/apache/accumulo/trace/thrift/SpanReceiver.java
+++ b/trace/src/main/java/org/apache/accumulo/trace/thrift/SpanReceiver.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class SpanReceiver {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class SpanReceiver {
 
   public interface Iface {
 
@@ -240,7 +240,7 @@ import org.slf4j.LoggerFactory;
     public RemoteSpan span; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SPAN((short)1, "span");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/trace/src/main/java/org/apache/accumulo/trace/thrift/TInfo.java
----------------------------------------------------------------------
diff --git a/trace/src/main/java/org/apache/accumulo/trace/thrift/TInfo.java b/trace/src/main/java/org/apache/accumulo/trace/thrift/TInfo.java
index 8e71aea..65fad13 100644
--- a/trace/src/main/java/org/apache/accumulo/trace/thrift/TInfo.java
+++ b/trace/src/main/java/org/apache/accumulo/trace/thrift/TInfo.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TInfo implements org.apache.thrift.TBase<TInfo, TInfo._Fields>, java.io.Serializable, Cloneable, Comparable<TInfo> {
+@SuppressWarnings({"unchecked", "rawtypes", "unused"}) public class TInfo implements org.apache.thrift.TBase<TInfo, TInfo._Fields>, java.io.Serializable, Cloneable, Comparable<TInfo> {
 
   private static final long serialVersionUID = -4659975753252858243l; // See ACCUMULO-3132
 
@@ -67,7 +67,7 @@ import org.slf4j.LoggerFactory;
   public long parentId; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     TRACE_ID((short)1, "traceId"),
     PARENT_ID((short)2, "parentId");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/trace/src/main/java/org/apache/accumulo/trace/thrift/TestService.java
----------------------------------------------------------------------
diff --git a/trace/src/main/java/org/apache/accumulo/trace/thrift/TestService.java b/trace/src/main/java/org/apache/accumulo/trace/thrift/TestService.java
index da5d64f..f1f5f9e 100644
--- a/trace/src/main/java/org/apache/accumulo/trace/thrift/TestService.java
+++ b/trace/src/main/java/org/apache/accumulo/trace/thrift/TestService.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TestService {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TestService {
 
   public interface Iface {
 
@@ -284,7 +284,7 @@ import org.slf4j.LoggerFactory;
     public String message; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       MESSAGE((short)2, "message");
 
@@ -741,7 +741,7 @@ import org.slf4j.LoggerFactory;
     public boolean success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/trace/src/main/scripts/generate-thrift.sh
----------------------------------------------------------------------
diff --git a/trace/src/main/scripts/generate-thrift.sh b/trace/src/main/scripts/generate-thrift.sh
index 0bb0005..c25782e 100755
--- a/trace/src/main/scripts/generate-thrift.sh
+++ b/trace/src/main/scripts/generate-thrift.sh
@@ -27,3 +27,7 @@ sed -i -e 's/\(public class TInfo .*\)$/\1\
 \
   private static final long serialVersionUID = -4659975753252858243l; \/\/ See ACCUMULO-3132\
 /' src/main/java/org/apache/accumulo/trace/thrift/TInfo.java
+
+# Remove unnecessary SuppressWarnings
+sed -i -e 's/"serial", //' src/main/java/org/apache/accumulo/trace/thrift/TInfo.java
+


[23/25] accumulo git commit: Merge branch '1.6' into 1.7

Posted by ct...@apache.org.
Merge branch '1.6' into 1.7

Conflicts:
	core/src/main/java/org/apache/accumulo/core/master/thrift/MasterClientService.java
	core/src/main/scripts/generate-thrift.sh
	core/src/test/java/org/apache/accumulo/core/iterators/AggregatingIteratorTest.java
	pom.xml
	server/tracer/src/main/scripts/generate-thrift.sh
	shell/src/main/java/org/apache/accumulo/shell/commands/AddSplitsCommand.java
	trace/src/main/java/org/apache/accumulo/trace/thrift/TInfo.java


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

Branch: refs/heads/1.7
Commit: 4d1acd14a1e864188e28a90e4c84f0389b052da4
Parents: ef2e31a bbcc6da
Author: Christopher Tubbs <ct...@apache.org>
Authored: Thu Apr 30 13:42:38 2015 -0400
Committer: Christopher Tubbs <ct...@apache.org>
Committed: Thu Apr 30 13:42:38 2015 -0400

----------------------------------------------------------------------
 core/src/main/scripts/generate-thrift.sh | 6 +++---
 pom.xml                                  | 6 ++++--
 2 files changed, 7 insertions(+), 5 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/4d1acd14/core/src/main/scripts/generate-thrift.sh
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/accumulo/blob/4d1acd14/pom.xml
----------------------------------------------------------------------
diff --cc pom.xml
index f680f84,9249a5b..c74ad2a
--- a/pom.xml
+++ b/pom.xml
@@@ -119,15 -118,15 +119,17 @@@
      <accumulo.release.version>${project.version}</accumulo.release.version>
      <!-- bouncycastle version for test dependencies -->
      <bouncycastle.version>1.50</bouncycastle.version>
+     <!-- findbugs-maven-plugin won't work on jdk8 or later; set to 3.0.0 or newer -->
 -    <findbugs.version>2.5.5</findbugs.version>
++    <findbugs.version>3.0.0</findbugs.version>
      <!-- surefire/failsafe plugin option -->
      <forkCount>1</forkCount>
 -    <!-- overwritten in profiles hadoop-1 or hadoop-2 -->
 +    <!-- overwritten in hadoop profiles -->
      <hadoop.version>2.2.0</hadoop.version>
 +    <htrace.version>3.1.0-incubating</htrace.version>
      <httpclient.version>3.1</httpclient.version>
 -    <java.ver>1.6</java.ver>
 -    <jetty.version>8.1.15.v20140411</jetty.version>
 +    <jetty.version>9.1.5.v20140505</jetty.version>
 +    <maven.compiler.source>1.7</maven.compiler.source>
 +    <maven.compiler.target>1.7</maven.compiler.target>
      <!-- the maven-release-plugin makes this recommendation, due to plugin bugs -->
      <maven.min-version>3.0.4</maven.min-version>
      <!-- surefire/failsafe plugin option -->


[03/25] accumulo git commit: ACCUMULO-3759 More Java 8 compiler warnings

Posted by ct...@apache.org.
ACCUMULO-3759 More Java 8 compiler warnings

* Fix compiler warnings in Java 8 for 1.5 branch


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

Branch: refs/heads/1.6
Commit: e395bc8ced5d740fe4a6e5d3ebb169335f64c044
Parents: 5ac1b52
Author: Christopher Tubbs <ct...@apache.org>
Authored: Thu Apr 30 12:04:50 2015 -0400
Committer: Christopher Tubbs <ct...@apache.org>
Committed: Thu Apr 30 12:04:50 2015 -0400

----------------------------------------------------------------------
 .../core/iterators/AggregatingIterator.java       | 18 ++++++++++--------
 .../aggregation/conf/AggregatorConfiguration.java |  3 +--
 .../iterators/aggregation/conf/AggregatorSet.java |  7 +++----
 .../util/shell/commands/AddSplitsCommand.java     | 18 +++++++++++++-----
 .../core/iterators/AggregatingIteratorTest.java   |  6 ++++--
 .../conf/AggregatorConfigurationTest.java         | 13 ++++++++-----
 .../org/apache/accumulo/server/master/Master.java | 16 ++++++++--------
 .../classloader/vfs/AccumuloVFSClassLoader.java   |  6 +++---
 8 files changed, 50 insertions(+), 37 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/e395bc8c/core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java b/core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java
index 28acc2b..13b2710 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java
@@ -27,7 +27,6 @@ import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.data.PartialKey;
 import org.apache.accumulo.core.data.Range;
 import org.apache.accumulo.core.data.Value;
-import org.apache.accumulo.core.iterators.aggregation.Aggregator;
 import org.apache.accumulo.core.iterators.conf.ColumnToClassMapping;
 import org.apache.accumulo.start.classloader.vfs.AccumuloVFSClassLoader;
 import org.apache.log4j.Logger;
@@ -42,7 +41,7 @@ import org.apache.log4j.Logger;
 public class AggregatingIterator implements SortedKeyValueIterator<Key,Value>, OptionDescriber {
 
   private SortedKeyValueIterator<Key,Value> iterator;
-  private ColumnToClassMapping<Aggregator> aggregators;
+  private ColumnToClassMapping<org.apache.accumulo.core.iterators.aggregation.Aggregator> aggregators;
 
   private Key workKey = new Key();
 
@@ -51,6 +50,7 @@ public class AggregatingIterator implements SortedKeyValueIterator<Key,Value>, O
   // private boolean propogateDeletes;
   private static final Logger log = Logger.getLogger(AggregatingIterator.class);
 
+  @Override
   public AggregatingIterator deepCopy(IteratorEnvironment env) {
     return new AggregatingIterator(this, env);
   }
@@ -62,7 +62,7 @@ public class AggregatingIterator implements SortedKeyValueIterator<Key,Value>, O
 
   public AggregatingIterator() {}
 
-  private void aggregateRowColumn(Aggregator aggr) throws IOException {
+  private void aggregateRowColumn(org.apache.accumulo.core.iterators.aggregation.Aggregator aggr) throws IOException {
     // this function assumes that first value is not delete
 
     if (iterator.getTopKey().isDeleted())
@@ -90,14 +90,15 @@ public class AggregatingIterator implements SortedKeyValueIterator<Key,Value>, O
   private void findTop() throws IOException {
     // check if aggregation is needed
     if (iterator.hasTop()) {
-      Aggregator aggr = aggregators.getObject(iterator.getTopKey());
+      org.apache.accumulo.core.iterators.aggregation.Aggregator aggr = aggregators.getObject(iterator.getTopKey());
       if (aggr != null) {
         aggregateRowColumn(aggr);
       }
     }
   }
 
-  public AggregatingIterator(SortedKeyValueIterator<Key,Value> iterator, ColumnToClassMapping<Aggregator> aggregators) throws IOException {
+  public AggregatingIterator(SortedKeyValueIterator<Key,Value> iterator,
+      ColumnToClassMapping<org.apache.accumulo.core.iterators.aggregation.Aggregator> aggregators) throws IOException {
     this.iterator = iterator;
     this.aggregators = aggregators;
   }
@@ -167,7 +168,8 @@ public class AggregatingIterator implements SortedKeyValueIterator<Key,Value>, O
     this.iterator = source;
 
     try {
-      this.aggregators = new ColumnToClassMapping<Aggregator>(options, Aggregator.class);
+      this.aggregators = new ColumnToClassMapping<org.apache.accumulo.core.iterators.aggregation.Aggregator>(options,
+          org.apache.accumulo.core.iterators.aggregation.Aggregator.class);
     } catch (ClassNotFoundException e) {
       log.error(e.toString());
       throw new IllegalArgumentException(e);
@@ -192,9 +194,9 @@ public class AggregatingIterator implements SortedKeyValueIterator<Key,Value>, O
       String classname = entry.getValue();
       if (classname == null)
         throw new IllegalArgumentException("classname null");
-      Class<? extends Aggregator> clazz;
+      Class<? extends org.apache.accumulo.core.iterators.aggregation.Aggregator> clazz;
       try {
-        clazz = AccumuloVFSClassLoader.loadClass(classname, Aggregator.class);
+        clazz = AccumuloVFSClassLoader.loadClass(classname, org.apache.accumulo.core.iterators.aggregation.Aggregator.class);
         clazz.newInstance();
       } catch (ClassNotFoundException e) {
         throw new IllegalArgumentException("class not found: " + classname);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/e395bc8c/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfiguration.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfiguration.java b/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfiguration.java
index 41c0374..3432cf5 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfiguration.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfiguration.java
@@ -16,14 +16,13 @@
  */
 package org.apache.accumulo.core.iterators.aggregation.conf;
 
-import org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig;
 import org.apache.hadoop.io.Text;
 
 /**
  * @deprecated since 1.4
  */
 @Deprecated
-public class AggregatorConfiguration extends PerColumnIteratorConfig {
+public class AggregatorConfiguration extends org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig {
 
   public AggregatorConfiguration(Text columnFamily, String aggClassName) {
     super(columnFamily, aggClassName);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/e395bc8c/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorSet.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorSet.java b/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorSet.java
index 26e2f11..37798b0 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorSet.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorSet.java
@@ -19,23 +19,22 @@ package org.apache.accumulo.core.iterators.aggregation.conf;
 import java.util.Map;
 
 import org.apache.accumulo.core.data.Key;
-import org.apache.accumulo.core.iterators.aggregation.Aggregator;
 import org.apache.accumulo.core.iterators.conf.ColumnToClassMapping;
 
 /**
  * @deprecated since 1.4
  */
 @Deprecated
-public class AggregatorSet extends ColumnToClassMapping<Aggregator> {
+public class AggregatorSet extends ColumnToClassMapping<org.apache.accumulo.core.iterators.aggregation.Aggregator> {
   public AggregatorSet(Map<String,String> opts) throws InstantiationException, IllegalAccessException, ClassNotFoundException {
-    super(opts, Aggregator.class);
+    super(opts, org.apache.accumulo.core.iterators.aggregation.Aggregator.class);
   }
 
   public AggregatorSet() {
     super();
   }
 
-  public Aggregator getAggregator(Key k) {
+  public org.apache.accumulo.core.iterators.aggregation.Aggregator getAggregator(Key k) {
     return getObject(k);
   }
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/e395bc8c/core/src/main/java/org/apache/accumulo/core/util/shell/commands/AddSplitsCommand.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/util/shell/commands/AddSplitsCommand.java b/core/src/main/java/org/apache/accumulo/core/util/shell/commands/AddSplitsCommand.java
index 3eab0a1..c88171a 100644
--- a/core/src/main/java/org/apache/accumulo/core/util/shell/commands/AddSplitsCommand.java
+++ b/core/src/main/java/org/apache/accumulo/core/util/shell/commands/AddSplitsCommand.java
@@ -34,6 +34,7 @@ import org.apache.hadoop.io.Text;
 public class AddSplitsCommand extends Command {
   private Option optSplitsFile, base64Opt;
 
+  @Override
   public int execute(final String fullCommand, final CommandLine cl, final Shell shellState) throws Exception {
     final String tableName = OptUtil.getTableOpt(cl, shellState);
     final boolean decode = cl.hasOption(base64Opt.getOpt());
@@ -44,11 +45,18 @@ public class AddSplitsCommand extends Command {
       final String f = cl.getOptionValue(optSplitsFile.getOpt());
 
       String line;
-      java.util.Scanner file = new java.util.Scanner(new File(f), UTF_8.name());
-      while (file.hasNextLine()) {
-        line = file.nextLine();
-        if (!line.isEmpty()) {
-          splits.add(decode ? new Text(Base64.decodeBase64(line.getBytes(UTF_8))) : new Text(line));
+      java.util.Scanner file = null;
+      try {
+        file = new java.util.Scanner(new File(f), UTF_8.name());
+        while (file.hasNextLine()) {
+          line = file.nextLine();
+          if (!line.isEmpty()) {
+            splits.add(decode ? new Text(Base64.decodeBase64(line.getBytes(UTF_8))) : new Text(line));
+          }
+        }
+      } finally {
+        if (file != null) {
+          file.close();
         }
       }
     } else {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/e395bc8c/core/src/test/java/org/apache/accumulo/core/iterators/AggregatingIteratorTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/iterators/AggregatingIteratorTest.java b/core/src/test/java/org/apache/accumulo/core/iterators/AggregatingIteratorTest.java
index 788366a..f1918b4 100644
--- a/core/src/test/java/org/apache/accumulo/core/iterators/AggregatingIteratorTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/iterators/AggregatingIteratorTest.java
@@ -31,7 +31,6 @@ import org.apache.accumulo.core.data.ByteSequence;
 import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.data.Range;
 import org.apache.accumulo.core.data.Value;
-import org.apache.accumulo.core.iterators.aggregation.Aggregator;
 import org.apache.accumulo.core.iterators.system.MultiIterator;
 import org.apache.hadoop.io.Text;
 
@@ -43,20 +42,23 @@ public class AggregatingIteratorTest extends TestCase {
 
   private static final Collection<ByteSequence> EMPTY_COL_FAMS = new ArrayList<ByteSequence>();
 
-  public static class SummationAggregator implements Aggregator {
+  public static class SummationAggregator implements org.apache.accumulo.core.iterators.aggregation.Aggregator {
 
     int sum;
 
+    @Override
     public Value aggregate() {
       return new Value((sum + "").getBytes());
     }
 
+    @Override
     public void collect(Value value) {
       int val = Integer.parseInt(value.toString());
 
       sum += val;
     }
 
+    @Override
     public void reset() {
       sum = 0;
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/e395bc8c/core/src/test/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfigurationTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfigurationTest.java b/core/src/test/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfigurationTest.java
index 1a285bc..6d666a3 100644
--- a/core/src/test/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfigurationTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfigurationTest.java
@@ -18,7 +18,6 @@ package org.apache.accumulo.core.iterators.aggregation.conf;
 
 import junit.framework.TestCase;
 
-import org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig;
 import org.apache.hadoop.io.Text;
 
 /**
@@ -46,18 +45,22 @@ public class AggregatorConfigurationTest extends TestCase {
 
   private void runTest(Text colf) {
     String encodedCols;
-    PerColumnIteratorConfig ac3 = new PerColumnIteratorConfig(colf, "com.foo.SuperAgg");
+    org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig ac3 = new org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig(colf,
+        "com.foo.SuperAgg");
     encodedCols = ac3.encodeColumns();
-    PerColumnIteratorConfig ac4 = PerColumnIteratorConfig.decodeColumns(encodedCols, "com.foo.SuperAgg");
+    org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig ac4 = org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig.decodeColumns(
+        encodedCols, "com.foo.SuperAgg");
 
     assertEquals(colf, ac4.getColumnFamily());
     assertNull(ac4.getColumnQualifier());
   }
 
   private void runTest(Text colf, Text colq) {
-    PerColumnIteratorConfig ac = new PerColumnIteratorConfig(colf, colq, "com.foo.SuperAgg");
+    org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig ac = new org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig(colf, colq,
+        "com.foo.SuperAgg");
     String encodedCols = ac.encodeColumns();
-    PerColumnIteratorConfig ac2 = PerColumnIteratorConfig.decodeColumns(encodedCols, "com.foo.SuperAgg");
+    org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig ac2 = org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig.decodeColumns(
+        encodedCols, "com.foo.SuperAgg");
 
     assertEquals(colf, ac2.getColumnFamily());
     assertEquals(colq, ac2.getColumnQualifier());

http://git-wip-us.apache.org/repos/asf/accumulo/blob/e395bc8c/server/src/main/java/org/apache/accumulo/server/master/Master.java
----------------------------------------------------------------------
diff --git a/server/src/main/java/org/apache/accumulo/server/master/Master.java b/server/src/main/java/org/apache/accumulo/server/master/Master.java
index 61ba7cf..dd94683 100644
--- a/server/src/main/java/org/apache/accumulo/server/master/Master.java
+++ b/server/src/main/java/org/apache/accumulo/server/master/Master.java
@@ -230,17 +230,17 @@ public class Master implements LiveTServerSet.Listener, TableObserver, CurrentSt
   }
 
   static final boolean X = true;
-  static final boolean _ = false;
+  static final boolean O = false;
   // @formatter:off
   static final boolean transitionOK[][] = {
       //                              INITIAL HAVE_LOCK SAFE_MODE NORMAL UNLOAD_META UNLOAD_ROOT STOP
-      /* INITIAL */                   {X,     X,        _,        _,      _,         _,          X},
-      /* HAVE_LOCK */                 {_,     X,        X,        X,      _,         _,          X},
-      /* SAFE_MODE */                 {_,     _,        X,        X,      X,         _,          X},
-      /* NORMAL */                    {_,     _,        X,        X,      X,         _,          X},
-      /* UNLOAD_METADATA_TABLETS */   {_,     _,        X,        X,      X,         X,          X},
-      /* UNLOAD_ROOT_TABLET */        {_,     _,        _,        X,      _,         X,          X},
-      /* STOP */                      {_,     _,        _,        _,      _,         _,          X}};
+      /* INITIAL */                   {X,     X,        O,        O,      O,         O,          X},
+      /* HAVE_LOCK */                 {O,     X,        X,        X,      O,         O,          X},
+      /* SAFE_MODE */                 {O,     O,        X,        X,      X,         O,          X},
+      /* NORMAL */                    {O,     O,        X,        X,      X,         O,          X},
+      /* UNLOAD_METADATA_TABLETS */   {O,     O,        X,        X,      X,         X,          X},
+      /* UNLOAD_ROOT_TABLET */        {O,     O,        O,        X,      O,         X,          X},
+      /* STOP */                      {O,     O,        O,        O,      O,         O,          X}};
   //@formatter:on
   synchronized private void setMasterState(MasterState newState) {
     if (state.equals(newState))

http://git-wip-us.apache.org/repos/asf/accumulo/blob/e395bc8c/start/src/main/java/org/apache/accumulo/start/classloader/vfs/AccumuloVFSClassLoader.java
----------------------------------------------------------------------
diff --git a/start/src/main/java/org/apache/accumulo/start/classloader/vfs/AccumuloVFSClassLoader.java b/start/src/main/java/org/apache/accumulo/start/classloader/vfs/AccumuloVFSClassLoader.java
index 7fa17d6..0abc79a 100644
--- a/start/src/main/java/org/apache/accumulo/start/classloader/vfs/AccumuloVFSClassLoader.java
+++ b/start/src/main/java/org/apache/accumulo/start/classloader/vfs/AccumuloVFSClassLoader.java
@@ -62,6 +62,7 @@ public class AccumuloVFSClassLoader {
 
   public static class AccumuloVFSClassLoaderShutdownThread implements Runnable {
 
+    @Override
     public void run() {
       try {
         AccumuloVFSClassLoader.close();
@@ -100,7 +101,7 @@ public class AccumuloVFSClassLoader {
 
   public synchronized static <U> Class<? extends U> loadClass(String classname, Class<U> extension) throws ClassNotFoundException {
     try {
-      return (Class<? extends U>) getClassLoader().loadClass(classname).asSubclass(extension);
+      return getClassLoader().loadClass(classname).asSubclass(extension);
     } catch (IOException e) {
       throw new ClassNotFoundException("IO Error loading class " + classname, e);
     }
@@ -326,10 +327,9 @@ public class AccumuloVFSClassLoader {
 
         if (classLoader instanceof URLClassLoader) {
           // If VFS class loader enabled, but no contexts defined.
-          URLClassLoader ucl = (URLClassLoader) classLoader;
           out.print("Level " + classLoaderDescription + " URL classpath items are:");
 
-          for (URL u : ucl.getURLs()) {
+          for (URL u : ((URLClassLoader) classLoader).getURLs()) {
             out.print("\t" + u.toExternalForm());
           }
 


[08/25] accumulo git commit: ACCUMULO-3759 More build warnings on Java 8

Posted by ct...@apache.org.
http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Condition.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Condition.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Condition.java
index 8dd28cf..c4b3c07 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Condition.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Condition.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class Condition implements org.apache.thrift.TBase<Condition, Condition._Fields>, java.io.Serializable, Cloneable, Comparable<Condition> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class Condition implements org.apache.thrift.TBase<Condition, Condition._Fields>, java.io.Serializable, Cloneable, Comparable<Condition> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("Condition");
 
   private static final org.apache.thrift.protocol.TField COLUMN_FIELD_DESC = new org.apache.thrift.protocol.TField("column", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -68,7 +68,7 @@ import org.slf4j.LoggerFactory;
   public List<IteratorSetting> iterators; // optional
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     COLUMN((short)1, "column"),
     TIMESTAMP((short)2, "timestamp"),
     VALUE((short)3, "value"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalStatus.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalStatus.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalStatus.java
index 55f0e62..515c416 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalStatus.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalStatus.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum ConditionalStatus implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum ConditionalStatus implements org.apache.thrift.TEnum {
   ACCEPTED(0),
   REJECTED(1),
   VIOLATED(2),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalUpdates.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalUpdates.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalUpdates.java
index 71806fe..551e996 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalUpdates.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalUpdates.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ConditionalUpdates implements org.apache.thrift.TBase<ConditionalUpdates, ConditionalUpdates._Fields>, java.io.Serializable, Cloneable, Comparable<ConditionalUpdates> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ConditionalUpdates implements org.apache.thrift.TBase<ConditionalUpdates, ConditionalUpdates._Fields>, java.io.Serializable, Cloneable, Comparable<ConditionalUpdates> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ConditionalUpdates");
 
   private static final org.apache.thrift.protocol.TField CONDITIONS_FIELD_DESC = new org.apache.thrift.protocol.TField("conditions", org.apache.thrift.protocol.TType.LIST, (short)2);
@@ -64,7 +64,7 @@ import org.slf4j.LoggerFactory;
   public List<ColumnUpdate> updates; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     CONDITIONS((short)2, "conditions"),
     UPDATES((short)3, "updates");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalWriterOptions.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalWriterOptions.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalWriterOptions.java
index bb4ad51..99c5172 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalWriterOptions.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ConditionalWriterOptions.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ConditionalWriterOptions implements org.apache.thrift.TBase<ConditionalWriterOptions, ConditionalWriterOptions._Fields>, java.io.Serializable, Cloneable, Comparable<ConditionalWriterOptions> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ConditionalWriterOptions implements org.apache.thrift.TBase<ConditionalWriterOptions, ConditionalWriterOptions._Fields>, java.io.Serializable, Cloneable, Comparable<ConditionalWriterOptions> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ConditionalWriterOptions");
 
   private static final org.apache.thrift.protocol.TField MAX_MEMORY_FIELD_DESC = new org.apache.thrift.protocol.TField("maxMemory", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -68,7 +68,7 @@ import org.slf4j.LoggerFactory;
   public Set<ByteBuffer> authorizations; // optional
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     MAX_MEMORY((short)1, "maxMemory"),
     TIMEOUT_MS((short)2, "timeoutMs"),
     THREADS((short)3, "threads"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/DiskUsage.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/DiskUsage.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/DiskUsage.java
index 36080ed..82a886d 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/DiskUsage.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/DiskUsage.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class DiskUsage implements org.apache.thrift.TBase<DiskUsage, DiskUsage._Fields>, java.io.Serializable, Cloneable, Comparable<DiskUsage> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class DiskUsage implements org.apache.thrift.TBase<DiskUsage, DiskUsage._Fields>, java.io.Serializable, Cloneable, Comparable<DiskUsage> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("DiskUsage");
 
   private static final org.apache.thrift.protocol.TField TABLES_FIELD_DESC = new org.apache.thrift.protocol.TField("tables", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -64,7 +64,7 @@ import org.slf4j.LoggerFactory;
   public long usage; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     TABLES((short)1, "tables"),
     USAGE((short)2, "usage");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/IteratorScope.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/IteratorScope.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/IteratorScope.java
index bafd525..0fc8de8 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/IteratorScope.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/IteratorScope.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum IteratorScope implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum IteratorScope implements org.apache.thrift.TEnum {
   MINC(0),
   MAJC(1),
   SCAN(2);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/IteratorSetting.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/IteratorSetting.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/IteratorSetting.java
index 1956b9a..eabc686 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/IteratorSetting.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/IteratorSetting.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class IteratorSetting implements org.apache.thrift.TBase<IteratorSetting, IteratorSetting._Fields>, java.io.Serializable, Cloneable, Comparable<IteratorSetting> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class IteratorSetting implements org.apache.thrift.TBase<IteratorSetting, IteratorSetting._Fields>, java.io.Serializable, Cloneable, Comparable<IteratorSetting> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("IteratorSetting");
 
   private static final org.apache.thrift.protocol.TField PRIORITY_FIELD_DESC = new org.apache.thrift.protocol.TField("priority", org.apache.thrift.protocol.TType.I32, (short)1);
@@ -68,7 +68,7 @@ import org.slf4j.LoggerFactory;
   public Map<String,String> properties; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     PRIORITY((short)1, "priority"),
     NAME((short)2, "name"),
     ITERATOR_CLASS((short)3, "iteratorClass"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Key.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Key.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Key.java
index ecba9d1..6984cf2 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Key.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Key.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class Key implements org.apache.thrift.TBase<Key, Key._Fields>, java.io.Serializable, Cloneable, Comparable<Key> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class Key implements org.apache.thrift.TBase<Key, Key._Fields>, java.io.Serializable, Cloneable, Comparable<Key> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("Key");
 
   private static final org.apache.thrift.protocol.TField ROW_FIELD_DESC = new org.apache.thrift.protocol.TField("row", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -70,7 +70,7 @@ import org.slf4j.LoggerFactory;
   public long timestamp; // optional
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     ROW((short)1, "row"),
     COL_FAMILY((short)2, "colFamily"),
     COL_QUALIFIER((short)3, "colQualifier"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyExtent.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyExtent.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyExtent.java
index f9c9e4c..1136284 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyExtent.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyExtent.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class KeyExtent implements org.apache.thrift.TBase<KeyExtent, KeyExtent._Fields>, java.io.Serializable, Cloneable, Comparable<KeyExtent> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class KeyExtent implements org.apache.thrift.TBase<KeyExtent, KeyExtent._Fields>, java.io.Serializable, Cloneable, Comparable<KeyExtent> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("KeyExtent");
 
   private static final org.apache.thrift.protocol.TField TABLE_ID_FIELD_DESC = new org.apache.thrift.protocol.TField("tableId", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -66,7 +66,7 @@ import org.slf4j.LoggerFactory;
   public ByteBuffer prevEndRow; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     TABLE_ID((short)1, "tableId"),
     END_ROW((short)2, "endRow"),
     PREV_END_ROW((short)3, "prevEndRow");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyValue.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyValue.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyValue.java
index 52bfbd1..76d71b5 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyValue.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyValue.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class KeyValue implements org.apache.thrift.TBase<KeyValue, KeyValue._Fields>, java.io.Serializable, Cloneable, Comparable<KeyValue> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class KeyValue implements org.apache.thrift.TBase<KeyValue, KeyValue._Fields>, java.io.Serializable, Cloneable, Comparable<KeyValue> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("KeyValue");
 
   private static final org.apache.thrift.protocol.TField KEY_FIELD_DESC = new org.apache.thrift.protocol.TField("key", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -64,7 +64,7 @@ import org.slf4j.LoggerFactory;
   public ByteBuffer value; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     KEY((short)1, "key"),
     VALUE((short)2, "value");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyValueAndPeek.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyValueAndPeek.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyValueAndPeek.java
index 1993d01..88b0c3f 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyValueAndPeek.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/KeyValueAndPeek.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class KeyValueAndPeek implements org.apache.thrift.TBase<KeyValueAndPeek, KeyValueAndPeek._Fields>, java.io.Serializable, Cloneable, Comparable<KeyValueAndPeek> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class KeyValueAndPeek implements org.apache.thrift.TBase<KeyValueAndPeek, KeyValueAndPeek._Fields>, java.io.Serializable, Cloneable, Comparable<KeyValueAndPeek> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("KeyValueAndPeek");
 
   private static final org.apache.thrift.protocol.TField KEY_VALUE_FIELD_DESC = new org.apache.thrift.protocol.TField("keyValue", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -64,7 +64,7 @@ import org.slf4j.LoggerFactory;
   public boolean hasNext; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     KEY_VALUE((short)1, "keyValue"),
     HAS_NEXT((short)2, "hasNext");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/MutationsRejectedException.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/MutationsRejectedException.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/MutationsRejectedException.java
index c0f8740..e5dfda1 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/MutationsRejectedException.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/MutationsRejectedException.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class MutationsRejectedException extends TException implements org.apache.thrift.TBase<MutationsRejectedException, MutationsRejectedException._Fields>, java.io.Serializable, Cloneable, Comparable<MutationsRejectedException> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class MutationsRejectedException extends TException implements org.apache.thrift.TBase<MutationsRejectedException, MutationsRejectedException._Fields>, java.io.Serializable, Cloneable, Comparable<MutationsRejectedException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("MutationsRejectedException");
 
   private static final org.apache.thrift.protocol.TField MSG_FIELD_DESC = new org.apache.thrift.protocol.TField("msg", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public String msg; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     MSG((short)1, "msg");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/NoMoreEntriesException.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/NoMoreEntriesException.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/NoMoreEntriesException.java
index b0a543a..d67bcd2 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/NoMoreEntriesException.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/NoMoreEntriesException.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class NoMoreEntriesException extends TException implements org.apache.thrift.TBase<NoMoreEntriesException, NoMoreEntriesException._Fields>, java.io.Serializable, Cloneable, Comparable<NoMoreEntriesException> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class NoMoreEntriesException extends TException implements org.apache.thrift.TBase<NoMoreEntriesException, NoMoreEntriesException._Fields>, java.io.Serializable, Cloneable, Comparable<NoMoreEntriesException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("NoMoreEntriesException");
 
   private static final org.apache.thrift.protocol.TField MSG_FIELD_DESC = new org.apache.thrift.protocol.TField("msg", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public String msg; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     MSG((short)1, "msg");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/PartialKey.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/PartialKey.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/PartialKey.java
index 1c9bfc4..2a0f269 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/PartialKey.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/PartialKey.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum PartialKey implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum PartialKey implements org.apache.thrift.TEnum {
   ROW(0),
   ROW_COLFAM(1),
   ROW_COLFAM_COLQUAL(2),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Range.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Range.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Range.java
index b1f505f..bc66c6b 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Range.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Range.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class Range implements org.apache.thrift.TBase<Range, Range._Fields>, java.io.Serializable, Cloneable, Comparable<Range> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class Range implements org.apache.thrift.TBase<Range, Range._Fields>, java.io.Serializable, Cloneable, Comparable<Range> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("Range");
 
   private static final org.apache.thrift.protocol.TField START_FIELD_DESC = new org.apache.thrift.protocol.TField("start", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -68,7 +68,7 @@ import org.slf4j.LoggerFactory;
   public boolean stopInclusive; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     START((short)1, "start"),
     START_INCLUSIVE((short)2, "startInclusive"),
     STOP((short)3, "stop"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanColumn.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanColumn.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanColumn.java
index 101d720..296c885 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanColumn.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanColumn.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ScanColumn implements org.apache.thrift.TBase<ScanColumn, ScanColumn._Fields>, java.io.Serializable, Cloneable, Comparable<ScanColumn> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ScanColumn implements org.apache.thrift.TBase<ScanColumn, ScanColumn._Fields>, java.io.Serializable, Cloneable, Comparable<ScanColumn> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ScanColumn");
 
   private static final org.apache.thrift.protocol.TField COL_FAMILY_FIELD_DESC = new org.apache.thrift.protocol.TField("colFamily", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -64,7 +64,7 @@ import org.slf4j.LoggerFactory;
   public ByteBuffer colQualifier; // optional
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     COL_FAMILY((short)1, "colFamily"),
     COL_QUALIFIER((short)2, "colQualifier");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanOptions.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanOptions.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanOptions.java
index 1e025ba..047daa0 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanOptions.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanOptions.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ScanOptions implements org.apache.thrift.TBase<ScanOptions, ScanOptions._Fields>, java.io.Serializable, Cloneable, Comparable<ScanOptions> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ScanOptions implements org.apache.thrift.TBase<ScanOptions, ScanOptions._Fields>, java.io.Serializable, Cloneable, Comparable<ScanOptions> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ScanOptions");
 
   private static final org.apache.thrift.protocol.TField AUTHORIZATIONS_FIELD_DESC = new org.apache.thrift.protocol.TField("authorizations", org.apache.thrift.protocol.TType.SET, (short)1);
@@ -70,7 +70,7 @@ import org.slf4j.LoggerFactory;
   public int bufferSize; // optional
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     AUTHORIZATIONS((short)1, "authorizations"),
     RANGE((short)2, "range"),
     COLUMNS((short)3, "columns"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanResult.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanResult.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanResult.java
index 02e1fe0..3775e7d 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanResult.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanResult.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ScanResult implements org.apache.thrift.TBase<ScanResult, ScanResult._Fields>, java.io.Serializable, Cloneable, Comparable<ScanResult> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ScanResult implements org.apache.thrift.TBase<ScanResult, ScanResult._Fields>, java.io.Serializable, Cloneable, Comparable<ScanResult> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ScanResult");
 
   private static final org.apache.thrift.protocol.TField RESULTS_FIELD_DESC = new org.apache.thrift.protocol.TField("results", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -64,7 +64,7 @@ import org.slf4j.LoggerFactory;
   public boolean more; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     RESULTS((short)1, "results"),
     MORE((short)2, "more");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanState.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanState.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanState.java
index 46608d1..127d147 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanState.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanState.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum ScanState implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum ScanState implements org.apache.thrift.TEnum {
   IDLE(0),
   RUNNING(1),
   QUEUED(2);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanType.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanType.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanType.java
index e153997..f417110 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanType.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ScanType.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum ScanType implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum ScanType implements org.apache.thrift.TEnum {
   SINGLE(0),
   BATCH(1);
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/SystemPermission.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/SystemPermission.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/SystemPermission.java
index 40e61d0..929b83a 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/SystemPermission.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/SystemPermission.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum SystemPermission implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum SystemPermission implements org.apache.thrift.TEnum {
   GRANT(0),
   CREATE_TABLE(1),
   DROP_TABLE(2),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TableExistsException.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TableExistsException.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TableExistsException.java
index 031de3a..9e3cf9c 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TableExistsException.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TableExistsException.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TableExistsException extends TException implements org.apache.thrift.TBase<TableExistsException, TableExistsException._Fields>, java.io.Serializable, Cloneable, Comparable<TableExistsException> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TableExistsException extends TException implements org.apache.thrift.TBase<TableExistsException, TableExistsException._Fields>, java.io.Serializable, Cloneable, Comparable<TableExistsException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TableExistsException");
 
   private static final org.apache.thrift.protocol.TField MSG_FIELD_DESC = new org.apache.thrift.protocol.TField("msg", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public String msg; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     MSG((short)1, "msg");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TableNotFoundException.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TableNotFoundException.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TableNotFoundException.java
index 6e8ec11..f12059b 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TableNotFoundException.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TableNotFoundException.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TableNotFoundException extends TException implements org.apache.thrift.TBase<TableNotFoundException, TableNotFoundException._Fields>, java.io.Serializable, Cloneable, Comparable<TableNotFoundException> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TableNotFoundException extends TException implements org.apache.thrift.TBase<TableNotFoundException, TableNotFoundException._Fields>, java.io.Serializable, Cloneable, Comparable<TableNotFoundException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TableNotFoundException");
 
   private static final org.apache.thrift.protocol.TField MSG_FIELD_DESC = new org.apache.thrift.protocol.TField("msg", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public String msg; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     MSG((short)1, "msg");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TablePermission.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TablePermission.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TablePermission.java
index f36d933..04882fa 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TablePermission.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TablePermission.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum TablePermission implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum TablePermission implements org.apache.thrift.TEnum {
   READ(2),
   WRITE(3),
   BULK_IMPORT(4),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TimeType.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TimeType.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TimeType.java
index b497ecc..32564e0 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TimeType.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/TimeType.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum TimeType implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum TimeType implements org.apache.thrift.TEnum {
   LOGICAL(0),
   MILLIS(1);
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/UnknownScanner.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/UnknownScanner.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/UnknownScanner.java
index a324af8..f6a4b1e 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/UnknownScanner.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/UnknownScanner.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class UnknownScanner extends TException implements org.apache.thrift.TBase<UnknownScanner, UnknownScanner._Fields>, java.io.Serializable, Cloneable, Comparable<UnknownScanner> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class UnknownScanner extends TException implements org.apache.thrift.TBase<UnknownScanner, UnknownScanner._Fields>, java.io.Serializable, Cloneable, Comparable<UnknownScanner> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("UnknownScanner");
 
   private static final org.apache.thrift.protocol.TField MSG_FIELD_DESC = new org.apache.thrift.protocol.TField("msg", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public String msg; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     MSG((short)1, "msg");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/UnknownWriter.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/UnknownWriter.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/UnknownWriter.java
index 5b83ae5..661aa1b 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/UnknownWriter.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/UnknownWriter.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class UnknownWriter extends TException implements org.apache.thrift.TBase<UnknownWriter, UnknownWriter._Fields>, java.io.Serializable, Cloneable, Comparable<UnknownWriter> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class UnknownWriter extends TException implements org.apache.thrift.TBase<UnknownWriter, UnknownWriter._Fields>, java.io.Serializable, Cloneable, Comparable<UnknownWriter> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("UnknownWriter");
 
   private static final org.apache.thrift.protocol.TField MSG_FIELD_DESC = new org.apache.thrift.protocol.TField("msg", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public String msg; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     MSG((short)1, "msg");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/WriterOptions.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/WriterOptions.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/WriterOptions.java
index 5f000a8..a57b995 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/WriterOptions.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/WriterOptions.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class WriterOptions implements org.apache.thrift.TBase<WriterOptions, WriterOptions._Fields>, java.io.Serializable, Cloneable, Comparable<WriterOptions> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class WriterOptions implements org.apache.thrift.TBase<WriterOptions, WriterOptions._Fields>, java.io.Serializable, Cloneable, Comparable<WriterOptions> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("WriterOptions");
 
   private static final org.apache.thrift.protocol.TField MAX_MEMORY_FIELD_DESC = new org.apache.thrift.protocol.TField("maxMemory", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -68,7 +68,7 @@ import org.slf4j.LoggerFactory;
   public int threads; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     MAX_MEMORY((short)1, "maxMemory"),
     LATENCY_MS((short)2, "latencyMs"),
     TIMEOUT_MS((short)3, "timeoutMs"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/trace/src/main/java/org/apache/accumulo/trace/thrift/RemoteSpan.java
----------------------------------------------------------------------
diff --git a/trace/src/main/java/org/apache/accumulo/trace/thrift/RemoteSpan.java b/trace/src/main/java/org/apache/accumulo/trace/thrift/RemoteSpan.java
index 416ae17..ffd66c8 100644
--- a/trace/src/main/java/org/apache/accumulo/trace/thrift/RemoteSpan.java
+++ b/trace/src/main/java/org/apache/accumulo/trace/thrift/RemoteSpan.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class RemoteSpan implements org.apache.thrift.TBase<RemoteSpan, RemoteSpan._Fields>, java.io.Serializable, Cloneable, Comparable<RemoteSpan> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class RemoteSpan implements org.apache.thrift.TBase<RemoteSpan, RemoteSpan._Fields>, java.io.Serializable, Cloneable, Comparable<RemoteSpan> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("RemoteSpan");
 
   private static final org.apache.thrift.protocol.TField SENDER_FIELD_DESC = new org.apache.thrift.protocol.TField("sender", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -78,7 +78,7 @@ import org.slf4j.LoggerFactory;
   public Map<String,String> data; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     SENDER((short)1, "sender"),
     SVC((short)2, "svc"),
     TRACE_ID((short)3, "traceId"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/trace/src/main/java/org/apache/accumulo/trace/thrift/SpanReceiver.java
----------------------------------------------------------------------
diff --git a/trace/src/main/java/org/apache/accumulo/trace/thrift/SpanReceiver.java b/trace/src/main/java/org/apache/accumulo/trace/thrift/SpanReceiver.java
index 4fe4c38..19b260f 100644
--- a/trace/src/main/java/org/apache/accumulo/trace/thrift/SpanReceiver.java
+++ b/trace/src/main/java/org/apache/accumulo/trace/thrift/SpanReceiver.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class SpanReceiver {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class SpanReceiver {
 
   public interface Iface {
 
@@ -240,7 +240,7 @@ import org.slf4j.LoggerFactory;
     public RemoteSpan span; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SPAN((short)1, "span");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/trace/src/main/java/org/apache/accumulo/trace/thrift/TInfo.java
----------------------------------------------------------------------
diff --git a/trace/src/main/java/org/apache/accumulo/trace/thrift/TInfo.java b/trace/src/main/java/org/apache/accumulo/trace/thrift/TInfo.java
index 8e71aea..65fad13 100644
--- a/trace/src/main/java/org/apache/accumulo/trace/thrift/TInfo.java
+++ b/trace/src/main/java/org/apache/accumulo/trace/thrift/TInfo.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TInfo implements org.apache.thrift.TBase<TInfo, TInfo._Fields>, java.io.Serializable, Cloneable, Comparable<TInfo> {
+@SuppressWarnings({"unchecked", "rawtypes", "unused"}) public class TInfo implements org.apache.thrift.TBase<TInfo, TInfo._Fields>, java.io.Serializable, Cloneable, Comparable<TInfo> {
 
   private static final long serialVersionUID = -4659975753252858243l; // See ACCUMULO-3132
 
@@ -67,7 +67,7 @@ import org.slf4j.LoggerFactory;
   public long parentId; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     TRACE_ID((short)1, "traceId"),
     PARENT_ID((short)2, "parentId");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/trace/src/main/java/org/apache/accumulo/trace/thrift/TestService.java
----------------------------------------------------------------------
diff --git a/trace/src/main/java/org/apache/accumulo/trace/thrift/TestService.java b/trace/src/main/java/org/apache/accumulo/trace/thrift/TestService.java
index da5d64f..f1f5f9e 100644
--- a/trace/src/main/java/org/apache/accumulo/trace/thrift/TestService.java
+++ b/trace/src/main/java/org/apache/accumulo/trace/thrift/TestService.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TestService {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TestService {
 
   public interface Iface {
 
@@ -284,7 +284,7 @@ import org.slf4j.LoggerFactory;
     public String message; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       MESSAGE((short)2, "message");
 
@@ -741,7 +741,7 @@ import org.slf4j.LoggerFactory;
     public boolean success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/trace/src/main/scripts/generate-thrift.sh
----------------------------------------------------------------------
diff --git a/trace/src/main/scripts/generate-thrift.sh b/trace/src/main/scripts/generate-thrift.sh
index 0bb0005..c25782e 100755
--- a/trace/src/main/scripts/generate-thrift.sh
+++ b/trace/src/main/scripts/generate-thrift.sh
@@ -27,3 +27,7 @@ sed -i -e 's/\(public class TInfo .*\)$/\1\
 \
   private static final long serialVersionUID = -4659975753252858243l; \/\/ See ACCUMULO-3132\
 /' src/main/java/org/apache/accumulo/trace/thrift/TInfo.java
+
+# Remove unnecessary SuppressWarnings
+sed -i -e 's/"serial", //' src/main/java/org/apache/accumulo/trace/thrift/TInfo.java
+


[17/25] accumulo git commit: ACCUMULO-3759 More build warnings on Java 8

Posted by ct...@apache.org.
ACCUMULO-3759 More build warnings on Java 8

* Clean up build output while generating example configs
* Fix javac warnings from thrift
* Enable specifying different findbugs version to build on jdk8


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

Branch: refs/heads/master
Commit: bbcc6da446b737507dfd9c486b5673055fbdf0ab
Parents: b636ff2
Author: Christopher Tubbs <ct...@apache.org>
Authored: Thu Apr 30 13:00:18 2015 -0400
Committer: Christopher Tubbs <ct...@apache.org>
Committed: Thu Apr 30 13:29:30 2015 -0400

----------------------------------------------------------------------
 .../main/scripts/generate-example-configs.sh    |   7 +-
 .../core/client/impl/thrift/ClientService.java  | 122 ++++----
 .../client/impl/thrift/ConfigurationType.java   |   2 +-
 .../client/impl/thrift/SecurityErrorCode.java   |   2 +-
 .../core/client/impl/thrift/TDiskUsage.java     |   4 +-
 .../core/client/impl/thrift/TableOperation.java |   2 +-
 .../thrift/TableOperationExceptionType.java     |   2 +-
 .../impl/thrift/ThriftSecurityException.java    |   4 +-
 .../thrift/ThriftTableOperationException.java   |   4 +-
 .../core/client/impl/thrift/ThriftTest.java     |  14 +-
 .../lib/impl/DistributedCacheHelper.java        |   7 +-
 .../core/data/thrift/InitialMultiScan.java      |   4 +-
 .../accumulo/core/data/thrift/InitialScan.java  |   4 +-
 .../accumulo/core/data/thrift/IterInfo.java     |   4 +-
 .../accumulo/core/data/thrift/MapFileInfo.java  |   4 +-
 .../core/data/thrift/MultiScanResult.java       |   4 +-
 .../accumulo/core/data/thrift/ScanResult.java   |   4 +-
 .../accumulo/core/data/thrift/TCMResult.java    |   4 +-
 .../accumulo/core/data/thrift/TCMStatus.java    |   2 +-
 .../accumulo/core/data/thrift/TColumn.java      |   4 +-
 .../accumulo/core/data/thrift/TCondition.java   |   4 +-
 .../core/data/thrift/TConditionalMutation.java  |   4 +-
 .../core/data/thrift/TConditionalSession.java   |   4 +-
 .../thrift/TConstraintViolationSummary.java     |   4 +-
 .../apache/accumulo/core/data/thrift/TKey.java  |   4 +-
 .../accumulo/core/data/thrift/TKeyExtent.java   |   4 +-
 .../accumulo/core/data/thrift/TKeyValue.java    |   4 +-
 .../accumulo/core/data/thrift/TMutation.java    |   4 +-
 .../accumulo/core/data/thrift/TRange.java       |   4 +-
 .../accumulo/core/data/thrift/UpdateErrors.java |   4 +-
 .../core/gc/thrift/GCMonitorService.java        |   6 +-
 .../accumulo/core/gc/thrift/GCStatus.java       |   4 +-
 .../accumulo/core/gc/thrift/GcCycleStats.java   |   4 +-
 .../accumulo/core/master/thrift/Compacting.java |   4 +-
 .../accumulo/core/master/thrift/DeadServer.java |   4 +-
 .../core/master/thrift/FateOperation.java       |   2 +-
 .../core/master/thrift/FateService.java         |  18 +-
 .../core/master/thrift/MasterClientService.java |  54 ++--
 .../core/master/thrift/MasterGoalState.java     |   2 +-
 .../core/master/thrift/MasterMonitorInfo.java   |   4 +-
 .../core/master/thrift/MasterState.java         |   2 +-
 .../core/master/thrift/RecoveryException.java   |   4 +-
 .../core/master/thrift/RecoveryStatus.java      |   4 +-
 .../accumulo/core/master/thrift/TableInfo.java  |   4 +-
 .../core/master/thrift/TabletLoadState.java     |   2 +-
 .../core/master/thrift/TabletServerStatus.java  |   4 +-
 .../core/master/thrift/TabletSplit.java         |   4 +-
 .../core/security/thrift/TCredentials.java      |   4 +-
 .../core/tabletserver/thrift/ActionStats.java   |   4 +-
 .../tabletserver/thrift/ActiveCompaction.java   |   4 +-
 .../core/tabletserver/thrift/ActiveScan.java    |   4 +-
 .../tabletserver/thrift/CompactionReason.java   |   2 +-
 .../tabletserver/thrift/CompactionType.java     |   2 +-
 .../thrift/ConstraintViolationException.java    |   4 +-
 .../tabletserver/thrift/IteratorConfig.java     |   4 +-
 .../thrift/NoSuchScanIDException.java           |   4 +-
 .../thrift/NotServingTabletException.java       |   4 +-
 .../core/tabletserver/thrift/ScanState.java     |   2 +-
 .../core/tabletserver/thrift/ScanType.java      |   2 +-
 .../tabletserver/thrift/TIteratorSetting.java   |   4 +-
 .../thrift/TabletClientService.java             | 100 +++---
 .../core/tabletserver/thrift/TabletStats.java   |   4 +-
 .../thrift/TooManyFilesException.java           |   4 +-
 core/src/main/scripts/generate-thrift.sh        |  50 +--
 pom.xml                                         |   6 +-
 .../proxy/thrift/AccumuloException.java         |   4 +-
 .../accumulo/proxy/thrift/AccumuloProxy.java    | 308 +++++++++----------
 .../proxy/thrift/AccumuloSecurityException.java |   4 +-
 .../accumulo/proxy/thrift/ActiveCompaction.java |   4 +-
 .../accumulo/proxy/thrift/ActiveScan.java       |   4 +-
 .../accumulo/proxy/thrift/BatchScanOptions.java |   4 +-
 .../apache/accumulo/proxy/thrift/Column.java    |   4 +-
 .../accumulo/proxy/thrift/ColumnUpdate.java     |   4 +-
 .../accumulo/proxy/thrift/CompactionReason.java |   2 +-
 .../accumulo/proxy/thrift/CompactionType.java   |   2 +-
 .../apache/accumulo/proxy/thrift/Condition.java |   4 +-
 .../proxy/thrift/ConditionalStatus.java         |   2 +-
 .../proxy/thrift/ConditionalUpdates.java        |   4 +-
 .../proxy/thrift/ConditionalWriterOptions.java  |   4 +-
 .../apache/accumulo/proxy/thrift/DiskUsage.java |   4 +-
 .../accumulo/proxy/thrift/IteratorScope.java    |   2 +-
 .../accumulo/proxy/thrift/IteratorSetting.java  |   4 +-
 .../org/apache/accumulo/proxy/thrift/Key.java   |   4 +-
 .../apache/accumulo/proxy/thrift/KeyExtent.java |   4 +-
 .../apache/accumulo/proxy/thrift/KeyValue.java  |   4 +-
 .../accumulo/proxy/thrift/KeyValueAndPeek.java  |   4 +-
 .../thrift/MutationsRejectedException.java      |   4 +-
 .../proxy/thrift/NoMoreEntriesException.java    |   4 +-
 .../accumulo/proxy/thrift/PartialKey.java       |   2 +-
 .../org/apache/accumulo/proxy/thrift/Range.java |   4 +-
 .../accumulo/proxy/thrift/ScanColumn.java       |   4 +-
 .../accumulo/proxy/thrift/ScanOptions.java      |   4 +-
 .../accumulo/proxy/thrift/ScanResult.java       |   4 +-
 .../apache/accumulo/proxy/thrift/ScanState.java |   2 +-
 .../apache/accumulo/proxy/thrift/ScanType.java  |   2 +-
 .../accumulo/proxy/thrift/SystemPermission.java |   2 +-
 .../proxy/thrift/TableExistsException.java      |   4 +-
 .../proxy/thrift/TableNotFoundException.java    |   4 +-
 .../accumulo/proxy/thrift/TablePermission.java  |   2 +-
 .../apache/accumulo/proxy/thrift/TimeType.java  |   2 +-
 .../accumulo/proxy/thrift/UnknownScanner.java   |   4 +-
 .../accumulo/proxy/thrift/UnknownWriter.java    |   4 +-
 .../accumulo/proxy/thrift/WriterOptions.java    |   4 +-
 .../accumulo/trace/thrift/RemoteSpan.java       |   4 +-
 .../accumulo/trace/thrift/SpanReceiver.java     |   4 +-
 .../org/apache/accumulo/trace/thrift/TInfo.java |   4 +-
 .../accumulo/trace/thrift/TestService.java      |   6 +-
 trace/src/main/scripts/generate-thrift.sh       |   4 +
 108 files changed, 523 insertions(+), 513 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/assemble/src/main/scripts/generate-example-configs.sh
----------------------------------------------------------------------
diff --git a/assemble/src/main/scripts/generate-example-configs.sh b/assemble/src/main/scripts/generate-example-configs.sh
index 16c9f4f..9dfbfe1 100755
--- a/assemble/src/main/scripts/generate-example-configs.sh
+++ b/assemble/src/main/scripts/generate-example-configs.sh
@@ -17,9 +17,12 @@
 
 # This script will regenerate the example configuration files for the tarball
 
+out=target/bootstrap-config.out
+
+echo 'Generating example scripts...' > $out
 for s in 1GB 2GB 3GB 512MB
 do
-  bin/bootstrap_config.sh -o -d target/example-configs/$s/standalone -s $s -j -v 2
-  bin/bootstrap_config.sh -o -d target/example-configs/$s/native-standalone -s $s -n -v 2
+  bin/bootstrap_config.sh -o -d target/example-configs/$s/standalone -s $s -j -v 2 >> $out 2>&1
+  bin/bootstrap_config.sh -o -d target/example-configs/$s/native-standalone -s $s -n -v 2 >> $out 2>&1
 done
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ClientService.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ClientService.java b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ClientService.java
index 638a8b7..5dd2cd5 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ClientService.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ClientService.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ClientService {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ClientService {
 
   public interface Iface {
 
@@ -4776,7 +4776,7 @@ import org.slf4j.LoggerFactory;
 
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
 ;
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -5024,7 +5024,7 @@ import org.slf4j.LoggerFactory;
     public String success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -5376,7 +5376,7 @@ import org.slf4j.LoggerFactory;
 
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
 ;
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -5624,7 +5624,7 @@ import org.slf4j.LoggerFactory;
     public String success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -5976,7 +5976,7 @@ import org.slf4j.LoggerFactory;
 
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
 ;
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -6224,7 +6224,7 @@ import org.slf4j.LoggerFactory;
     public String success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -6590,7 +6590,7 @@ import org.slf4j.LoggerFactory;
     public boolean setTime; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)8, "credentials"),
       TID((short)3, "tid"),
@@ -7587,7 +7587,7 @@ import org.slf4j.LoggerFactory;
     public ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
@@ -8192,7 +8192,7 @@ import org.slf4j.LoggerFactory;
     public long tid; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       TID((short)2, "tid");
 
@@ -8647,7 +8647,7 @@ import org.slf4j.LoggerFactory;
     public boolean success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -9001,7 +9001,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.security.thrift.TCredentials credentials; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       CREDENTIALS((short)2, "credentials");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -9360,7 +9360,7 @@ import org.slf4j.LoggerFactory;
     public ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -9718,7 +9718,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.security.thrift.TCredentials credentials; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TABLES((short)2, "tables"),
       CREDENTIALS((short)1, "credentials");
 
@@ -10228,7 +10228,7 @@ import org.slf4j.LoggerFactory;
     public ThriftTableOperationException toe; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec"),
       TOE((short)2, "toe");
@@ -10838,7 +10838,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.security.thrift.TCredentials credentials; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       CREDENTIALS((short)3, "credentials");
 
@@ -11302,7 +11302,7 @@ import org.slf4j.LoggerFactory;
     public ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -11811,7 +11811,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer password; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)5, "tinfo"),
       CREDENTIALS((short)6, "credentials"),
       PRINCIPAL((short)2, "principal"),
@@ -12480,7 +12480,7 @@ import org.slf4j.LoggerFactory;
     public ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -12840,7 +12840,7 @@ import org.slf4j.LoggerFactory;
     public String principal; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)4, "credentials"),
       PRINCIPAL((short)2, "principal");
@@ -13400,7 +13400,7 @@ import org.slf4j.LoggerFactory;
     public ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -13762,7 +13762,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer password; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)4, "tinfo"),
       CREDENTIALS((short)5, "credentials"),
       PRINCIPAL((short)2, "principal"),
@@ -14431,7 +14431,7 @@ import org.slf4j.LoggerFactory;
     public ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -14789,7 +14789,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.security.thrift.TCredentials credentials; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)2, "credentials");
 
@@ -15253,7 +15253,7 @@ import org.slf4j.LoggerFactory;
     public ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -15711,7 +15711,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.security.thrift.TCredentials toAuth; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)2, "credentials"),
       TO_AUTH((short)3, "toAuth");
@@ -16278,7 +16278,7 @@ import org.slf4j.LoggerFactory;
     public ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -16738,7 +16738,7 @@ import org.slf4j.LoggerFactory;
     public List<ByteBuffer> authorizations; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)4, "tinfo"),
       CREDENTIALS((short)5, "credentials"),
       PRINCIPAL((short)2, "principal"),
@@ -17445,7 +17445,7 @@ import org.slf4j.LoggerFactory;
     public ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -17805,7 +17805,7 @@ import org.slf4j.LoggerFactory;
     public String principal; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)4, "credentials"),
       PRINCIPAL((short)2, "principal");
@@ -18367,7 +18367,7 @@ import org.slf4j.LoggerFactory;
     public ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -18876,7 +18876,7 @@ import org.slf4j.LoggerFactory;
     public byte sysPerm; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)4, "tinfo"),
       CREDENTIALS((short)5, "credentials"),
       PRINCIPAL((short)2, "principal"),
@@ -19534,7 +19534,7 @@ import org.slf4j.LoggerFactory;
     public ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -19996,7 +19996,7 @@ import org.slf4j.LoggerFactory;
     public byte tblPerm; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)5, "tinfo"),
       CREDENTIALS((short)6, "credentials"),
       PRINCIPAL((short)2, "principal"),
@@ -20754,7 +20754,7 @@ import org.slf4j.LoggerFactory;
     public ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
@@ -21316,7 +21316,7 @@ import org.slf4j.LoggerFactory;
     public byte tblNspcPerm; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)2, "credentials"),
       PRINCIPAL((short)3, "principal"),
@@ -22074,7 +22074,7 @@ import org.slf4j.LoggerFactory;
     public ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
@@ -22634,7 +22634,7 @@ import org.slf4j.LoggerFactory;
     public byte permission; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)4, "tinfo"),
       CREDENTIALS((short)5, "credentials"),
       PRINCIPAL((short)2, "principal"),
@@ -23290,7 +23290,7 @@ import org.slf4j.LoggerFactory;
     public ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -23652,7 +23652,7 @@ import org.slf4j.LoggerFactory;
     public byte permission; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)4, "tinfo"),
       CREDENTIALS((short)5, "credentials"),
       PRINCIPAL((short)2, "principal"),
@@ -24308,7 +24308,7 @@ import org.slf4j.LoggerFactory;
     public ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -24672,7 +24672,7 @@ import org.slf4j.LoggerFactory;
     public byte permission; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)5, "tinfo"),
       CREDENTIALS((short)6, "credentials"),
       PRINCIPAL((short)2, "principal"),
@@ -25428,7 +25428,7 @@ import org.slf4j.LoggerFactory;
     public ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
 
@@ -25892,7 +25892,7 @@ import org.slf4j.LoggerFactory;
     public byte permission; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)5, "tinfo"),
       CREDENTIALS((short)6, "credentials"),
       PRINCIPAL((short)2, "principal"),
@@ -26648,7 +26648,7 @@ import org.slf4j.LoggerFactory;
     public ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
 
@@ -27112,7 +27112,7 @@ import org.slf4j.LoggerFactory;
     public byte permission; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)2, "credentials"),
       PRINCIPAL((short)3, "principal"),
@@ -27868,7 +27868,7 @@ import org.slf4j.LoggerFactory;
     public ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
 
@@ -28332,7 +28332,7 @@ import org.slf4j.LoggerFactory;
     public byte permission; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)2, "credentials"),
       PRINCIPAL((short)3, "principal"),
@@ -29088,7 +29088,7 @@ import org.slf4j.LoggerFactory;
     public ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
 
@@ -29552,7 +29552,7 @@ import org.slf4j.LoggerFactory;
     public ConfigurationType type; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       CREDENTIALS((short)3, "credentials"),
       /**
@@ -30124,7 +30124,7 @@ import org.slf4j.LoggerFactory;
     public Map<String,String> success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -30534,7 +30534,7 @@ import org.slf4j.LoggerFactory;
     public String tableName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)3, "credentials"),
       TABLE_NAME((short)2, "tableName");
@@ -31096,7 +31096,7 @@ import org.slf4j.LoggerFactory;
     public ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       TOPE((short)1, "tope");
 
@@ -31606,7 +31606,7 @@ import org.slf4j.LoggerFactory;
     public String ns; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)2, "credentials"),
       NS((short)3, "ns");
@@ -32168,7 +32168,7 @@ import org.slf4j.LoggerFactory;
     public ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       TOPE((short)1, "tope");
 
@@ -32680,7 +32680,7 @@ import org.slf4j.LoggerFactory;
     public String interfaceMatch; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)4, "credentials"),
       CLASS_NAME((short)2, "className"),
@@ -33338,7 +33338,7 @@ import org.slf4j.LoggerFactory;
     public boolean success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -33700,7 +33700,7 @@ import org.slf4j.LoggerFactory;
     public String interfaceMatch; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)5, "credentials"),
       TABLE_ID((short)2, "tableId"),
@@ -34460,7 +34460,7 @@ import org.slf4j.LoggerFactory;
     public ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
@@ -35022,7 +35022,7 @@ import org.slf4j.LoggerFactory;
     public String interfaceMatch; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)2, "credentials"),
       NAMESPACE_ID((short)3, "namespaceId"),
@@ -35782,7 +35782,7 @@ import org.slf4j.LoggerFactory;
     public ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ConfigurationType.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ConfigurationType.java b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ConfigurationType.java
index f5be98c..7399802 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ConfigurationType.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ConfigurationType.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum ConfigurationType implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum ConfigurationType implements org.apache.thrift.TEnum {
   CURRENT(0),
   SITE(1),
   DEFAULT(2);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/SecurityErrorCode.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/SecurityErrorCode.java b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/SecurityErrorCode.java
index 111cffa..754f24e 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/SecurityErrorCode.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/SecurityErrorCode.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum SecurityErrorCode implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum SecurityErrorCode implements org.apache.thrift.TEnum {
   DEFAULT_SECURITY_ERROR(0),
   BAD_CREDENTIALS(1),
   PERMISSION_DENIED(2),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TDiskUsage.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TDiskUsage.java b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TDiskUsage.java
index 1b85d47..1ae011b 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TDiskUsage.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TDiskUsage.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TDiskUsage implements org.apache.thrift.TBase<TDiskUsage, TDiskUsage._Fields>, java.io.Serializable, Cloneable, Comparable<TDiskUsage> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TDiskUsage implements org.apache.thrift.TBase<TDiskUsage, TDiskUsage._Fields>, java.io.Serializable, Cloneable, Comparable<TDiskUsage> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TDiskUsage");
 
   private static final org.apache.thrift.protocol.TField TABLES_FIELD_DESC = new org.apache.thrift.protocol.TField("tables", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -64,7 +64,7 @@ import org.slf4j.LoggerFactory;
   public long usage; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     TABLES((short)1, "tables"),
     USAGE((short)2, "usage");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TableOperation.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TableOperation.java b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TableOperation.java
index 7716823..4730276 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TableOperation.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TableOperation.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum TableOperation implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum TableOperation implements org.apache.thrift.TEnum {
   CREATE(0),
   DELETE(1),
   RENAME(2),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TableOperationExceptionType.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TableOperationExceptionType.java b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TableOperationExceptionType.java
index baea21e..48b5619 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TableOperationExceptionType.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/TableOperationExceptionType.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum TableOperationExceptionType implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum TableOperationExceptionType implements org.apache.thrift.TEnum {
   EXISTS(0),
   NOTFOUND(1),
   OFFLINE(2),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftSecurityException.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftSecurityException.java b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftSecurityException.java
index a6500e5..9e94830 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftSecurityException.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftSecurityException.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ThriftSecurityException extends TException implements org.apache.thrift.TBase<ThriftSecurityException, ThriftSecurityException._Fields>, java.io.Serializable, Cloneable, Comparable<ThriftSecurityException> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ThriftSecurityException extends TException implements org.apache.thrift.TBase<ThriftSecurityException, ThriftSecurityException._Fields>, java.io.Serializable, Cloneable, Comparable<ThriftSecurityException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ThriftSecurityException");
 
   private static final org.apache.thrift.protocol.TField USER_FIELD_DESC = new org.apache.thrift.protocol.TField("user", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -68,7 +68,7 @@ import org.slf4j.LoggerFactory;
   public SecurityErrorCode code; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     USER((short)1, "user"),
     /**
      * 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftTableOperationException.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftTableOperationException.java b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftTableOperationException.java
index 0c8ab4b..fad7ea7 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftTableOperationException.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftTableOperationException.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ThriftTableOperationException extends TException implements org.apache.thrift.TBase<ThriftTableOperationException, ThriftTableOperationException._Fields>, java.io.Serializable, Cloneable, Comparable<ThriftTableOperationException> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ThriftTableOperationException extends TException implements org.apache.thrift.TBase<ThriftTableOperationException, ThriftTableOperationException._Fields>, java.io.Serializable, Cloneable, Comparable<ThriftTableOperationException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ThriftTableOperationException");
 
   private static final org.apache.thrift.protocol.TField TABLE_ID_FIELD_DESC = new org.apache.thrift.protocol.TField("tableId", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -78,7 +78,7 @@ import org.slf4j.LoggerFactory;
   public String description; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     TABLE_ID((short)1, "tableId"),
     TABLE_NAME((short)2, "tableName"),
     /**

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftTest.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftTest.java b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftTest.java
index 5f785ff..c4af921 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftTest.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/thrift/ThriftTest.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ThriftTest {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ThriftTest {
 
   public interface Iface {
 
@@ -545,7 +545,7 @@ import org.slf4j.LoggerFactory;
 
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
 ;
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -793,7 +793,7 @@ import org.slf4j.LoggerFactory;
     public boolean success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -1145,7 +1145,7 @@ import org.slf4j.LoggerFactory;
 
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
 ;
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -1393,7 +1393,7 @@ import org.slf4j.LoggerFactory;
     public boolean success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -1745,7 +1745,7 @@ import org.slf4j.LoggerFactory;
 
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
 ;
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -1995,7 +1995,7 @@ import org.slf4j.LoggerFactory;
     public ThriftSecurityException ex; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       EX((short)1, "ex");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/client/mapreduce/lib/impl/DistributedCacheHelper.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/lib/impl/DistributedCacheHelper.java b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/lib/impl/DistributedCacheHelper.java
index c694b9a..a5e603b 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/lib/impl/DistributedCacheHelper.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/lib/impl/DistributedCacheHelper.java
@@ -20,7 +20,6 @@ import java.io.IOException;
 import java.net.URI;
 
 import org.apache.hadoop.conf.Configuration;
-import org.apache.hadoop.filecache.DistributedCache;
 import org.apache.hadoop.fs.Path;
 
 /**
@@ -33,20 +32,20 @@ public class DistributedCacheHelper {
    * @since 1.6.0
    */
   public static void addCacheFile(URI uri, Configuration conf) {
-    DistributedCache.addCacheFile(uri, conf);
+    org.apache.hadoop.filecache.DistributedCache.addCacheFile(uri, conf);
   }
 
   /**
    * @since 1.6.0
    */
   public static URI[] getCacheFiles(Configuration conf) throws IOException {
-    return DistributedCache.getCacheFiles(conf);
+    return org.apache.hadoop.filecache.DistributedCache.getCacheFiles(conf);
   }
 
   /**
    * @since 1.6.0
    */
   public static Path[] getLocalCacheFiles(Configuration conf) throws IOException {
-    return DistributedCache.getLocalCacheFiles(conf);
+    return org.apache.hadoop.filecache.DistributedCache.getLocalCacheFiles(conf);
   }
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/InitialMultiScan.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/InitialMultiScan.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/InitialMultiScan.java
index d4d5424..d124c14 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/InitialMultiScan.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/InitialMultiScan.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class InitialMultiScan implements org.apache.thrift.TBase<InitialMultiScan, InitialMultiScan._Fields>, java.io.Serializable, Cloneable, Comparable<InitialMultiScan> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class InitialMultiScan implements org.apache.thrift.TBase<InitialMultiScan, InitialMultiScan._Fields>, java.io.Serializable, Cloneable, Comparable<InitialMultiScan> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("InitialMultiScan");
 
   private static final org.apache.thrift.protocol.TField SCAN_ID_FIELD_DESC = new org.apache.thrift.protocol.TField("scanID", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -64,7 +64,7 @@ import org.slf4j.LoggerFactory;
   public MultiScanResult result; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     SCAN_ID((short)1, "scanID"),
     RESULT((short)2, "result");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/InitialScan.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/InitialScan.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/InitialScan.java
index 001bc51..38239d7 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/InitialScan.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/InitialScan.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class InitialScan implements org.apache.thrift.TBase<InitialScan, InitialScan._Fields>, java.io.Serializable, Cloneable, Comparable<InitialScan> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class InitialScan implements org.apache.thrift.TBase<InitialScan, InitialScan._Fields>, java.io.Serializable, Cloneable, Comparable<InitialScan> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("InitialScan");
 
   private static final org.apache.thrift.protocol.TField SCAN_ID_FIELD_DESC = new org.apache.thrift.protocol.TField("scanID", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -64,7 +64,7 @@ import org.slf4j.LoggerFactory;
   public ScanResult result; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     SCAN_ID((short)1, "scanID"),
     RESULT((short)2, "result");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/IterInfo.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/IterInfo.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/IterInfo.java
index 6135634..890a6b8 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/IterInfo.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/IterInfo.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class IterInfo implements org.apache.thrift.TBase<IterInfo, IterInfo._Fields>, java.io.Serializable, Cloneable, Comparable<IterInfo> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class IterInfo implements org.apache.thrift.TBase<IterInfo, IterInfo._Fields>, java.io.Serializable, Cloneable, Comparable<IterInfo> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("IterInfo");
 
   private static final org.apache.thrift.protocol.TField PRIORITY_FIELD_DESC = new org.apache.thrift.protocol.TField("priority", org.apache.thrift.protocol.TType.I32, (short)1);
@@ -66,7 +66,7 @@ import org.slf4j.LoggerFactory;
   public String iterName; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     PRIORITY((short)1, "priority"),
     CLASS_NAME((short)2, "className"),
     ITER_NAME((short)3, "iterName");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/MapFileInfo.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/MapFileInfo.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/MapFileInfo.java
index 8598818..0fbf04f 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/MapFileInfo.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/MapFileInfo.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class MapFileInfo implements org.apache.thrift.TBase<MapFileInfo, MapFileInfo._Fields>, java.io.Serializable, Cloneable, Comparable<MapFileInfo> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class MapFileInfo implements org.apache.thrift.TBase<MapFileInfo, MapFileInfo._Fields>, java.io.Serializable, Cloneable, Comparable<MapFileInfo> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("MapFileInfo");
 
   private static final org.apache.thrift.protocol.TField ESTIMATED_SIZE_FIELD_DESC = new org.apache.thrift.protocol.TField("estimatedSize", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public long estimatedSize; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     ESTIMATED_SIZE((short)1, "estimatedSize");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/MultiScanResult.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/MultiScanResult.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/MultiScanResult.java
index d7c0374..0140a68 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/MultiScanResult.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/MultiScanResult.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class MultiScanResult implements org.apache.thrift.TBase<MultiScanResult, MultiScanResult._Fields>, java.io.Serializable, Cloneable, Comparable<MultiScanResult> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class MultiScanResult implements org.apache.thrift.TBase<MultiScanResult, MultiScanResult._Fields>, java.io.Serializable, Cloneable, Comparable<MultiScanResult> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("MultiScanResult");
 
   private static final org.apache.thrift.protocol.TField RESULTS_FIELD_DESC = new org.apache.thrift.protocol.TField("results", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -74,7 +74,7 @@ import org.slf4j.LoggerFactory;
   public boolean more; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     RESULTS((short)1, "results"),
     FAILURES((short)2, "failures"),
     FULL_SCANS((short)3, "fullScans"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/ScanResult.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/ScanResult.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/ScanResult.java
index ce418a6..b936d2b 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/ScanResult.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/ScanResult.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ScanResult implements org.apache.thrift.TBase<ScanResult, ScanResult._Fields>, java.io.Serializable, Cloneable, Comparable<ScanResult> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ScanResult implements org.apache.thrift.TBase<ScanResult, ScanResult._Fields>, java.io.Serializable, Cloneable, Comparable<ScanResult> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ScanResult");
 
   private static final org.apache.thrift.protocol.TField RESULTS_FIELD_DESC = new org.apache.thrift.protocol.TField("results", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -64,7 +64,7 @@ import org.slf4j.LoggerFactory;
   public boolean more; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     RESULTS((short)1, "results"),
     MORE((short)2, "more");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/TCMResult.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/TCMResult.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/TCMResult.java
index 598bd48..7c60cd1 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/TCMResult.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/TCMResult.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TCMResult implements org.apache.thrift.TBase<TCMResult, TCMResult._Fields>, java.io.Serializable, Cloneable, Comparable<TCMResult> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TCMResult implements org.apache.thrift.TBase<TCMResult, TCMResult._Fields>, java.io.Serializable, Cloneable, Comparable<TCMResult> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TCMResult");
 
   private static final org.apache.thrift.protocol.TField CMID_FIELD_DESC = new org.apache.thrift.protocol.TField("cmid", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -68,7 +68,7 @@ import org.slf4j.LoggerFactory;
   public TCMStatus status; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     CMID((short)1, "cmid"),
     /**
      * 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/TCMStatus.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/TCMStatus.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/TCMStatus.java
index ee4592c..993e9e2 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/TCMStatus.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/TCMStatus.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum TCMStatus implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum TCMStatus implements org.apache.thrift.TEnum {
   ACCEPTED(0),
   REJECTED(1),
   VIOLATED(2),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/TColumn.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/TColumn.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/TColumn.java
index 125cece..127f7c6 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/TColumn.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/TColumn.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TColumn implements org.apache.thrift.TBase<TColumn, TColumn._Fields>, java.io.Serializable, Cloneable, Comparable<TColumn> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TColumn implements org.apache.thrift.TBase<TColumn, TColumn._Fields>, java.io.Serializable, Cloneable, Comparable<TColumn> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TColumn");
 
   private static final org.apache.thrift.protocol.TField COLUMN_FAMILY_FIELD_DESC = new org.apache.thrift.protocol.TField("columnFamily", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -66,7 +66,7 @@ import org.slf4j.LoggerFactory;
   public ByteBuffer columnVisibility; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     COLUMN_FAMILY((short)1, "columnFamily"),
     COLUMN_QUALIFIER((short)2, "columnQualifier"),
     COLUMN_VISIBILITY((short)3, "columnVisibility");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/TCondition.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/TCondition.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/TCondition.java
index 9fc3968..a4ae6df 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/TCondition.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/TCondition.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TCondition implements org.apache.thrift.TBase<TCondition, TCondition._Fields>, java.io.Serializable, Cloneable, Comparable<TCondition> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TCondition implements org.apache.thrift.TBase<TCondition, TCondition._Fields>, java.io.Serializable, Cloneable, Comparable<TCondition> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TCondition");
 
   private static final org.apache.thrift.protocol.TField CF_FIELD_DESC = new org.apache.thrift.protocol.TField("cf", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -74,7 +74,7 @@ import org.slf4j.LoggerFactory;
   public ByteBuffer iterators; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     CF((short)1, "cf"),
     CQ((short)2, "cq"),
     CV((short)3, "cv"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/TConditionalMutation.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/TConditionalMutation.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/TConditionalMutation.java
index 3d49c45..8c9f0a6 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/TConditionalMutation.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/TConditionalMutation.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TConditionalMutation implements org.apache.thrift.TBase<TConditionalMutation, TConditionalMutation._Fields>, java.io.Serializable, Cloneable, Comparable<TConditionalMutation> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TConditionalMutation implements org.apache.thrift.TBase<TConditionalMutation, TConditionalMutation._Fields>, java.io.Serializable, Cloneable, Comparable<TConditionalMutation> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TConditionalMutation");
 
   private static final org.apache.thrift.protocol.TField CONDITIONS_FIELD_DESC = new org.apache.thrift.protocol.TField("conditions", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -66,7 +66,7 @@ import org.slf4j.LoggerFactory;
   public long id; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     CONDITIONS((short)1, "conditions"),
     MUTATION((short)2, "mutation"),
     ID((short)3, "id");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/TConditionalSession.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/TConditionalSession.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/TConditionalSession.java
index 646dbdb..eb08623 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/TConditionalSession.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/TConditionalSession.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TConditionalSession implements org.apache.thrift.TBase<TConditionalSession, TConditionalSession._Fields>, java.io.Serializable, Cloneable, Comparable<TConditionalSession> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TConditionalSession implements org.apache.thrift.TBase<TConditionalSession, TConditionalSession._Fields>, java.io.Serializable, Cloneable, Comparable<TConditionalSession> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TConditionalSession");
 
   private static final org.apache.thrift.protocol.TField SESSION_ID_FIELD_DESC = new org.apache.thrift.protocol.TField("sessionId", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -66,7 +66,7 @@ import org.slf4j.LoggerFactory;
   public long ttl; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     SESSION_ID((short)1, "sessionId"),
     TSERVER_LOCK((short)2, "tserverLock"),
     TTL((short)3, "ttl");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/TConstraintViolationSummary.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/TConstraintViolationSummary.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/TConstraintViolationSummary.java
index d841eff..1dc51e3 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/TConstraintViolationSummary.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/TConstraintViolationSummary.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TConstraintViolationSummary implements org.apache.thrift.TBase<TConstraintViolationSummary, TConstraintViolationSummary._Fields>, java.io.Serializable, Cloneable, Comparable<TConstraintViolationSummary> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TConstraintViolationSummary implements org.apache.thrift.TBase<TConstraintViolationSummary, TConstraintViolationSummary._Fields>, java.io.Serializable, Cloneable, Comparable<TConstraintViolationSummary> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TConstraintViolationSummary");
 
   private static final org.apache.thrift.protocol.TField CONSTRAIN_CLASS_FIELD_DESC = new org.apache.thrift.protocol.TField("constrainClass", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -68,7 +68,7 @@ import org.slf4j.LoggerFactory;
   public long numberOfViolatingMutations; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     CONSTRAIN_CLASS((short)1, "constrainClass"),
     VIOLATION_CODE((short)2, "violationCode"),
     VIOLATION_DESCRIPTION((short)3, "violationDescription"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/TKey.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/TKey.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/TKey.java
index 4f05c66..2b81651 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/TKey.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/TKey.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TKey implements org.apache.thrift.TBase<TKey, TKey._Fields>, java.io.Serializable, Cloneable, Comparable<TKey> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TKey implements org.apache.thrift.TBase<TKey, TKey._Fields>, java.io.Serializable, Cloneable, Comparable<TKey> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TKey");
 
   private static final org.apache.thrift.protocol.TField ROW_FIELD_DESC = new org.apache.thrift.protocol.TField("row", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -70,7 +70,7 @@ import org.slf4j.LoggerFactory;
   public long timestamp; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     ROW((short)1, "row"),
     COL_FAMILY((short)2, "colFamily"),
     COL_QUALIFIER((short)3, "colQualifier"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/TKeyExtent.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/TKeyExtent.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/TKeyExtent.java
index b83fc1a..20f1fea 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/TKeyExtent.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/TKeyExtent.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TKeyExtent implements org.apache.thrift.TBase<TKeyExtent, TKeyExtent._Fields>, java.io.Serializable, Cloneable, Comparable<TKeyExtent> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TKeyExtent implements org.apache.thrift.TBase<TKeyExtent, TKeyExtent._Fields>, java.io.Serializable, Cloneable, Comparable<TKeyExtent> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TKeyExtent");
 
   private static final org.apache.thrift.protocol.TField TABLE_FIELD_DESC = new org.apache.thrift.protocol.TField("table", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -66,7 +66,7 @@ import org.slf4j.LoggerFactory;
   public ByteBuffer prevEndRow; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     TABLE((short)1, "table"),
     END_ROW((short)2, "endRow"),
     PREV_END_ROW((short)3, "prevEndRow");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/TKeyValue.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/TKeyValue.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/TKeyValue.java
index 4c47c69..75161b0 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/TKeyValue.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/TKeyValue.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TKeyValue implements org.apache.thrift.TBase<TKeyValue, TKeyValue._Fields>, java.io.Serializable, Cloneable, Comparable<TKeyValue> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TKeyValue implements org.apache.thrift.TBase<TKeyValue, TKeyValue._Fields>, java.io.Serializable, Cloneable, Comparable<TKeyValue> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TKeyValue");
 
   private static final org.apache.thrift.protocol.TField KEY_FIELD_DESC = new org.apache.thrift.protocol.TField("key", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -64,7 +64,7 @@ import org.slf4j.LoggerFactory;
   public ByteBuffer value; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     KEY((short)1, "key"),
     VALUE((short)2, "value");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/TMutation.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/TMutation.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/TMutation.java
index 1e00047..ecaf87c 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/TMutation.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/TMutation.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TMutation implements org.apache.thrift.TBase<TMutation, TMutation._Fields>, java.io.Serializable, Cloneable, Comparable<TMutation> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TMutation implements org.apache.thrift.TBase<TMutation, TMutation._Fields>, java.io.Serializable, Cloneable, Comparable<TMutation> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TMutation");
 
   private static final org.apache.thrift.protocol.TField ROW_FIELD_DESC = new org.apache.thrift.protocol.TField("row", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -68,7 +68,7 @@ import org.slf4j.LoggerFactory;
   public int entries; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     ROW((short)1, "row"),
     DATA((short)2, "data"),
     VALUES((short)3, "values"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/TRange.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/TRange.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/TRange.java
index 58e805f..0ad791c 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/TRange.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/TRange.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TRange implements org.apache.thrift.TBase<TRange, TRange._Fields>, java.io.Serializable, Cloneable, Comparable<TRange> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TRange implements org.apache.thrift.TBase<TRange, TRange._Fields>, java.io.Serializable, Cloneable, Comparable<TRange> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TRange");
 
   private static final org.apache.thrift.protocol.TField START_FIELD_DESC = new org.apache.thrift.protocol.TField("start", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -72,7 +72,7 @@ import org.slf4j.LoggerFactory;
   public boolean infiniteStopKey; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     START((short)1, "start"),
     STOP((short)2, "stop"),
     START_KEY_INCLUSIVE((short)3, "startKeyInclusive"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/data/thrift/UpdateErrors.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/thrift/UpdateErrors.java b/core/src/main/java/org/apache/accumulo/core/data/thrift/UpdateErrors.java
index 55a0602..f2b53ad 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/thrift/UpdateErrors.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/thrift/UpdateErrors.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class UpdateErrors implements org.apache.thrift.TBase<UpdateErrors, UpdateErrors._Fields>, java.io.Serializable, Cloneable, Comparable<UpdateErrors> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class UpdateErrors implements org.apache.thrift.TBase<UpdateErrors, UpdateErrors._Fields>, java.io.Serializable, Cloneable, Comparable<UpdateErrors> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("UpdateErrors");
 
   private static final org.apache.thrift.protocol.TField FAILED_EXTENTS_FIELD_DESC = new org.apache.thrift.protocol.TField("failedExtents", org.apache.thrift.protocol.TType.MAP, (short)1);
@@ -66,7 +66,7 @@ import org.slf4j.LoggerFactory;
   public Map<TKeyExtent,org.apache.accumulo.core.client.impl.thrift.SecurityErrorCode> authorizationFailures; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     FAILED_EXTENTS((short)1, "failedExtents"),
     VIOLATION_SUMMARIES((short)2, "violationSummaries"),
     AUTHORIZATION_FAILURES((short)3, "authorizationFailures");


[19/25] accumulo git commit: ACCUMULO-3759 More build warnings on Java 8

Posted by ct...@apache.org.
http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloProxy.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloProxy.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloProxy.java
index 3b23175..b22da8f 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloProxy.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloProxy.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class AccumuloProxy {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class AccumuloProxy {
 
   public interface Iface {
 
@@ -12719,7 +12719,7 @@ import org.slf4j.LoggerFactory;
     public Map<String,String> loginProperties; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       PRINCIPAL((short)1, "principal"),
       LOGIN_PROPERTIES((short)2, "loginProperties");
 
@@ -13225,7 +13225,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH2((short)1, "ouch2");
 
@@ -13694,7 +13694,7 @@ import org.slf4j.LoggerFactory;
     public String constraintClassName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       CONSTRAINT_CLASS_NAME((short)3, "constraintClassName");
@@ -14261,7 +14261,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -14919,7 +14919,7 @@ import org.slf4j.LoggerFactory;
     public Set<ByteBuffer> splits; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       SPLITS((short)3, "splits");
@@ -15533,7 +15533,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -16095,7 +16095,7 @@ import org.slf4j.LoggerFactory;
     public Set<IteratorScope> scopes; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       SETTING((short)3, "setting"),
@@ -16815,7 +16815,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -17377,7 +17377,7 @@ import org.slf4j.LoggerFactory;
     public Set<IteratorScope> scopes; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       SETTING((short)3, "setting"),
@@ -18097,7 +18097,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -18655,7 +18655,7 @@ import org.slf4j.LoggerFactory;
     public String tableName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName");
 
@@ -19118,7 +19118,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch1; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -19484,7 +19484,7 @@ import org.slf4j.LoggerFactory;
     public Set<String> propertiesToExclude; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       NEW_TABLE_NAME((short)3, "newTableName"),
@@ -20444,7 +20444,7 @@ import org.slf4j.LoggerFactory;
     public TableExistsException ouch4; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3"),
@@ -21112,7 +21112,7 @@ import org.slf4j.LoggerFactory;
     public boolean wait; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       START_ROW((short)3, "startRow"),
@@ -22137,7 +22137,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -22695,7 +22695,7 @@ import org.slf4j.LoggerFactory;
     public String tableName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName");
 
@@ -23162,7 +23162,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -23728,7 +23728,7 @@ import org.slf4j.LoggerFactory;
     public TimeType type; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       VERSIONING_ITER((short)3, "versioningIter"),
@@ -24401,7 +24401,7 @@ import org.slf4j.LoggerFactory;
     public TableExistsException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -24959,7 +24959,7 @@ import org.slf4j.LoggerFactory;
     public String tableName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName");
 
@@ -25426,7 +25426,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -25988,7 +25988,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer endRow; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       START_ROW((short)3, "startRow"),
@@ -26673,7 +26673,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -27233,7 +27233,7 @@ import org.slf4j.LoggerFactory;
     public String exportDir; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       EXPORT_DIR((short)3, "exportDir");
@@ -27798,7 +27798,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -28362,7 +28362,7 @@ import org.slf4j.LoggerFactory;
     public boolean wait; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       START_ROW((short)3, "startRow"),
@@ -29143,7 +29143,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -29701,7 +29701,7 @@ import org.slf4j.LoggerFactory;
     public Set<String> tables; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLES((short)2, "tables");
 
@@ -30219,7 +30219,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -30929,7 +30929,7 @@ import org.slf4j.LoggerFactory;
     public String tableName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName");
 
@@ -31398,7 +31398,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -32158,7 +32158,7 @@ import org.slf4j.LoggerFactory;
     public IteratorScope scope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       ITERATOR_NAME((short)3, "iteratorName"),
@@ -32835,7 +32835,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -33506,7 +33506,7 @@ import org.slf4j.LoggerFactory;
     public boolean endInclusive; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       AUTHS((short)3, "auths"),
@@ -34528,7 +34528,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -35195,7 +35195,7 @@ import org.slf4j.LoggerFactory;
     public String tableName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName");
 
@@ -35664,7 +35664,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -36378,7 +36378,7 @@ import org.slf4j.LoggerFactory;
     public boolean setTime; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       IMPORT_DIR((short)3, "importDir"),
@@ -37137,7 +37137,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch4; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH3((short)2, "ouch3"),
       OUCH4((short)3, "ouch4");
@@ -37697,7 +37697,7 @@ import org.slf4j.LoggerFactory;
     public String importDir; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       IMPORT_DIR((short)3, "importDir");
@@ -38262,7 +38262,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -38822,7 +38822,7 @@ import org.slf4j.LoggerFactory;
     public int maxSplits; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       MAX_SPLITS((short)3, "maxSplits");
@@ -39387,7 +39387,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -40090,7 +40090,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer login; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -40455,7 +40455,7 @@ import org.slf4j.LoggerFactory;
     public Set<String> success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -40860,7 +40860,7 @@ import org.slf4j.LoggerFactory;
     public String tableName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName");
 
@@ -41329,7 +41329,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -42084,7 +42084,7 @@ import org.slf4j.LoggerFactory;
     public String tableName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName");
 
@@ -42553,7 +42553,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -43265,7 +43265,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer endRow; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       START_ROW((short)3, "startRow"),
@@ -43950,7 +43950,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -44510,7 +44510,7 @@ import org.slf4j.LoggerFactory;
     public boolean wait; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       WAIT((short)3, "wait");
@@ -45075,7 +45075,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -45635,7 +45635,7 @@ import org.slf4j.LoggerFactory;
     public boolean wait; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       WAIT((short)3, "wait");
@@ -46200,7 +46200,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -46760,7 +46760,7 @@ import org.slf4j.LoggerFactory;
     public int constraint; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       CONSTRAINT((short)3, "constraint");
@@ -47323,7 +47323,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -47885,7 +47885,7 @@ import org.slf4j.LoggerFactory;
     public Set<IteratorScope> scopes; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       ITER_NAME((short)3, "iterName"),
@@ -48600,7 +48600,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -49160,7 +49160,7 @@ import org.slf4j.LoggerFactory;
     public String property; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       PROPERTY((short)3, "property");
@@ -49725,7 +49725,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -50285,7 +50285,7 @@ import org.slf4j.LoggerFactory;
     public String newTableName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       OLD_TABLE_NAME((short)2, "oldTableName"),
       NEW_TABLE_NAME((short)3, "newTableName");
@@ -50852,7 +50852,7 @@ import org.slf4j.LoggerFactory;
     public TableExistsException ouch4; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3"),
@@ -51512,7 +51512,7 @@ import org.slf4j.LoggerFactory;
     public Map<String,Set<String>> groups; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       GROUPS((short)3, "groups");
@@ -52173,7 +52173,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -52735,7 +52735,7 @@ import org.slf4j.LoggerFactory;
     public String value; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       PROPERTY((short)3, "property"),
@@ -53398,7 +53398,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -53960,7 +53960,7 @@ import org.slf4j.LoggerFactory;
     public int maxSplits; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       RANGE((short)3, "range"),
@@ -54628,7 +54628,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -55338,7 +55338,7 @@ import org.slf4j.LoggerFactory;
     public String tableName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName");
 
@@ -55801,7 +55801,7 @@ import org.slf4j.LoggerFactory;
     public boolean success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -56155,7 +56155,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer login; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -56520,7 +56520,7 @@ import org.slf4j.LoggerFactory;
     public Map<String,String> success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -56932,7 +56932,7 @@ import org.slf4j.LoggerFactory;
     public String asTypeName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       CLASS_NAME((short)3, "className"),
@@ -57597,7 +57597,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -58253,7 +58253,7 @@ import org.slf4j.LoggerFactory;
     public String tserver; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TSERVER((short)2, "tserver");
 
@@ -58718,7 +58718,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
 
@@ -59176,7 +59176,7 @@ import org.slf4j.LoggerFactory;
     public String tserver; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TSERVER((short)2, "tserver");
 
@@ -59643,7 +59643,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
@@ -60253,7 +60253,7 @@ import org.slf4j.LoggerFactory;
     public String tserver; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TSERVER((short)2, "tserver");
 
@@ -60720,7 +60720,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
@@ -61328,7 +61328,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer login; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -61697,7 +61697,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
@@ -62303,7 +62303,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer login; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -62672,7 +62672,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
@@ -63278,7 +63278,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer login; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -63643,7 +63643,7 @@ import org.slf4j.LoggerFactory;
     public List<String> success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -64048,7 +64048,7 @@ import org.slf4j.LoggerFactory;
     public String property; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       PROPERTY((short)2, "property");
 
@@ -64513,7 +64513,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
 
@@ -64973,7 +64973,7 @@ import org.slf4j.LoggerFactory;
     public String value; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       PROPERTY((short)2, "property"),
       VALUE((short)3, "value");
@@ -65536,7 +65536,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
 
@@ -65996,7 +65996,7 @@ import org.slf4j.LoggerFactory;
     public String asTypeName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       CLASS_NAME((short)2, "className"),
       AS_TYPE_NAME((short)3, "asTypeName");
@@ -66561,7 +66561,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
@@ -67119,7 +67119,7 @@ import org.slf4j.LoggerFactory;
     public Map<String,String> properties; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       USER((short)2, "user"),
       PROPERTIES((short)3, "properties");
@@ -67736,7 +67736,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
@@ -68294,7 +68294,7 @@ import org.slf4j.LoggerFactory;
     public Set<ByteBuffer> authorizations; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       USER((short)2, "user"),
       AUTHORIZATIONS((short)3, "authorizations");
@@ -68906,7 +68906,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
 
@@ -69366,7 +69366,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer password; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       USER((short)2, "user"),
       PASSWORD((short)3, "password");
@@ -69940,7 +69940,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
 
@@ -70400,7 +70400,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer password; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       USER((short)2, "user"),
       PASSWORD((short)3, "password");
@@ -70974,7 +70974,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
 
@@ -71432,7 +71432,7 @@ import org.slf4j.LoggerFactory;
     public String user; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       USER((short)2, "user");
 
@@ -71897,7 +71897,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
 
@@ -72355,7 +72355,7 @@ import org.slf4j.LoggerFactory;
     public String user; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       USER((short)2, "user");
 
@@ -72822,7 +72822,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
@@ -73433,7 +73433,7 @@ import org.slf4j.LoggerFactory;
     public SystemPermission perm; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       USER((short)2, "user"),
       /**
@@ -74008,7 +74008,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
 
@@ -74474,7 +74474,7 @@ import org.slf4j.LoggerFactory;
     public TablePermission perm; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       USER((short)2, "user"),
       TABLE((short)3, "table"),
@@ -75149,7 +75149,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -75713,7 +75713,7 @@ import org.slf4j.LoggerFactory;
     public SystemPermission perm; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       USER((short)2, "user"),
       /**
@@ -76290,7 +76290,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
@@ -76854,7 +76854,7 @@ import org.slf4j.LoggerFactory;
     public TablePermission perm; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       USER((short)2, "user"),
       TABLE((short)3, "table"),
@@ -77531,7 +77531,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -78185,7 +78185,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer login; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -78556,7 +78556,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -79267,7 +79267,7 @@ import org.slf4j.LoggerFactory;
     public SystemPermission perm; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       USER((short)2, "user"),
       /**
@@ -79842,7 +79842,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
 
@@ -80308,7 +80308,7 @@ import org.slf4j.LoggerFactory;
     public TablePermission perm; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       USER((short)2, "user"),
       TABLE((short)3, "table"),
@@ -80983,7 +80983,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -81543,7 +81543,7 @@ import org.slf4j.LoggerFactory;
     public BatchScanOptions options; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       OPTIONS((short)3, "options");
@@ -82115,7 +82115,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -82773,7 +82773,7 @@ import org.slf4j.LoggerFactory;
     public ScanOptions options; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       OPTIONS((short)3, "options");
@@ -83345,7 +83345,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -83999,7 +83999,7 @@ import org.slf4j.LoggerFactory;
     public String scanner; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SCANNER((short)1, "scanner");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -84355,7 +84355,7 @@ import org.slf4j.LoggerFactory;
     public UnknownScanner ouch1; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1");
 
@@ -84809,7 +84809,7 @@ import org.slf4j.LoggerFactory;
     public String scanner; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SCANNER((short)1, "scanner");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -85169,7 +85169,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -85830,7 +85830,7 @@ import org.slf4j.LoggerFactory;
     public int k; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SCANNER((short)1, "scanner"),
       K((short)2, "k");
 
@@ -86286,7 +86286,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -86945,7 +86945,7 @@ import org.slf4j.LoggerFactory;
     public String scanner; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SCANNER((short)1, "scanner");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -87299,7 +87299,7 @@ import org.slf4j.LoggerFactory;
     public UnknownScanner ouch1; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -87659,7 +87659,7 @@ import org.slf4j.LoggerFactory;
     public Map<ByteBuffer,List<ColumnUpdate>> cells; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       CELLS((short)3, "cells");
@@ -88328,7 +88328,7 @@ import org.slf4j.LoggerFactory;
     public MutationsRejectedException ouch4; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUTCH1((short)1, "outch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3"),
@@ -88988,7 +88988,7 @@ import org.slf4j.LoggerFactory;
     public WriterOptions opts; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       OPTS((short)3, "opts");
@@ -89560,7 +89560,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUTCH1((short)1, "outch1"),
       OUCH2((short)2, "ouch2"),
@@ -90216,7 +90216,7 @@ import org.slf4j.LoggerFactory;
     public Map<ByteBuffer,List<ColumnUpdate>> cells; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       WRITER((short)1, "writer"),
       CELLS((short)2, "cells");
 
@@ -90770,7 +90770,7 @@ import org.slf4j.LoggerFactory;
     public String writer; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       WRITER((short)1, "writer");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -91126,7 +91126,7 @@ import org.slf4j.LoggerFactory;
     public MutationsRejectedException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
 
@@ -91582,7 +91582,7 @@ import org.slf4j.LoggerFactory;
     public String writer; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       WRITER((short)1, "writer");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -91938,7 +91938,7 @@ import org.slf4j.LoggerFactory;
     public MutationsRejectedException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
 
@@ -92400,7 +92400,7 @@ import org.slf4j.LoggerFactory;
     public ConditionalUpdates updates; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       ROW((short)3, "row"),
@@ -93085,7 +93085,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       /**
        * 
        * @see ConditionalStatus
@@ -93755,7 +93755,7 @@ import org.slf4j.LoggerFactory;
     public ConditionalWriterOptions options; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       OPTIONS((short)3, "options");
@@ -94327,7 +94327,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -94983,7 +94983,7 @@ import org.slf4j.LoggerFactory;
     public Map<ByteBuffer,ConditionalUpdates> updates; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       CONDITIONAL_WRITER((short)1, "conditionalWriter"),
       UPDATES((short)2, "updates");
 
@@ -95507,7 +95507,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -96225,7 +96225,7 @@ import org.slf4j.LoggerFactory;
     public String conditionalWriter; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       CONDITIONAL_WRITER((short)1, "conditionalWriter");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -96577,7 +96577,7 @@ import org.slf4j.LoggerFactory;
 
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
 ;
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -96825,7 +96825,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer row; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       ROW((short)1, "row");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -97190,7 +97190,7 @@ import org.slf4j.LoggerFactory;
     public Range success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -97555,7 +97555,7 @@ import org.slf4j.LoggerFactory;
     public PartialKey part; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       KEY((short)1, "key"),
       /**
        * 
@@ -98024,7 +98024,7 @@ import org.slf4j.LoggerFactory;
     public Key success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloSecurityException.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloSecurityException.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloSecurityException.java
index 55e074b..28b1e6c 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloSecurityException.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloSecurityException.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class AccumuloSecurityException extends TException implements org.apache.thrift.TBase<AccumuloSecurityException, AccumuloSecurityException._Fields>, java.io.Serializable, Cloneable, Comparable<AccumuloSecurityException> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class AccumuloSecurityException extends TException implements org.apache.thrift.TBase<AccumuloSecurityException, AccumuloSecurityException._Fields>, java.io.Serializable, Cloneable, Comparable<AccumuloSecurityException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("AccumuloSecurityException");
 
   private static final org.apache.thrift.protocol.TField MSG_FIELD_DESC = new org.apache.thrift.protocol.TField("msg", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public String msg; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     MSG((short)1, "msg");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ActiveCompaction.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ActiveCompaction.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ActiveCompaction.java
index 05de413..58e1321 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ActiveCompaction.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ActiveCompaction.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ActiveCompaction implements org.apache.thrift.TBase<ActiveCompaction, ActiveCompaction._Fields>, java.io.Serializable, Cloneable, Comparable<ActiveCompaction> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ActiveCompaction implements org.apache.thrift.TBase<ActiveCompaction, ActiveCompaction._Fields>, java.io.Serializable, Cloneable, Comparable<ActiveCompaction> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ActiveCompaction");
 
   private static final org.apache.thrift.protocol.TField EXTENT_FIELD_DESC = new org.apache.thrift.protocol.TField("extent", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -88,7 +88,7 @@ import org.slf4j.LoggerFactory;
   public List<IteratorSetting> iterators; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     EXTENT((short)1, "extent"),
     AGE((short)2, "age"),
     INPUT_FILES((short)3, "inputFiles"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ActiveScan.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ActiveScan.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ActiveScan.java
index a34e57f..bc9ad51 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ActiveScan.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ActiveScan.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ActiveScan implements org.apache.thrift.TBase<ActiveScan, ActiveScan._Fields>, java.io.Serializable, Cloneable, Comparable<ActiveScan> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ActiveScan implements org.apache.thrift.TBase<ActiveScan, ActiveScan._Fields>, java.io.Serializable, Cloneable, Comparable<ActiveScan> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ActiveScan");
 
   private static final org.apache.thrift.protocol.TField CLIENT_FIELD_DESC = new org.apache.thrift.protocol.TField("client", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -90,7 +90,7 @@ import org.slf4j.LoggerFactory;
   public List<ByteBuffer> authorizations; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     CLIENT((short)1, "client"),
     USER((short)2, "user"),
     TABLE((short)3, "table"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/BatchScanOptions.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/BatchScanOptions.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/BatchScanOptions.java
index e749ac4..948d822 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/BatchScanOptions.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/BatchScanOptions.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class BatchScanOptions implements org.apache.thrift.TBase<BatchScanOptions, BatchScanOptions._Fields>, java.io.Serializable, Cloneable, Comparable<BatchScanOptions> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class BatchScanOptions implements org.apache.thrift.TBase<BatchScanOptions, BatchScanOptions._Fields>, java.io.Serializable, Cloneable, Comparable<BatchScanOptions> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("BatchScanOptions");
 
   private static final org.apache.thrift.protocol.TField AUTHORIZATIONS_FIELD_DESC = new org.apache.thrift.protocol.TField("authorizations", org.apache.thrift.protocol.TType.SET, (short)1);
@@ -70,7 +70,7 @@ import org.slf4j.LoggerFactory;
   public int threads; // optional
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     AUTHORIZATIONS((short)1, "authorizations"),
     RANGES((short)2, "ranges"),
     COLUMNS((short)3, "columns"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Column.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Column.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Column.java
index 3c20017..007eb53 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Column.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Column.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class Column implements org.apache.thrift.TBase<Column, Column._Fields>, java.io.Serializable, Cloneable, Comparable<Column> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class Column implements org.apache.thrift.TBase<Column, Column._Fields>, java.io.Serializable, Cloneable, Comparable<Column> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("Column");
 
   private static final org.apache.thrift.protocol.TField COL_FAMILY_FIELD_DESC = new org.apache.thrift.protocol.TField("colFamily", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -66,7 +66,7 @@ import org.slf4j.LoggerFactory;
   public ByteBuffer colVisibility; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     COL_FAMILY((short)1, "colFamily"),
     COL_QUALIFIER((short)2, "colQualifier"),
     COL_VISIBILITY((short)3, "colVisibility");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ColumnUpdate.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ColumnUpdate.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ColumnUpdate.java
index a3b040e..97d9542 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ColumnUpdate.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ColumnUpdate.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ColumnUpdate implements org.apache.thrift.TBase<ColumnUpdate, ColumnUpdate._Fields>, java.io.Serializable, Cloneable, Comparable<ColumnUpdate> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ColumnUpdate implements org.apache.thrift.TBase<ColumnUpdate, ColumnUpdate._Fields>, java.io.Serializable, Cloneable, Comparable<ColumnUpdate> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ColumnUpdate");
 
   private static final org.apache.thrift.protocol.TField COL_FAMILY_FIELD_DESC = new org.apache.thrift.protocol.TField("colFamily", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -72,7 +72,7 @@ import org.slf4j.LoggerFactory;
   public boolean deleteCell; // optional
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     COL_FAMILY((short)1, "colFamily"),
     COL_QUALIFIER((short)2, "colQualifier"),
     COL_VISIBILITY((short)3, "colVisibility"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/CompactionReason.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/CompactionReason.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/CompactionReason.java
index 36bc32a..1875275 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/CompactionReason.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/CompactionReason.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum CompactionReason implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum CompactionReason implements org.apache.thrift.TEnum {
   USER(0),
   SYSTEM(1),
   CHOP(2),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/CompactionType.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/CompactionType.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/CompactionType.java
index c0a5171..1b82951 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/CompactionType.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/CompactionType.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum CompactionType implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum CompactionType implements org.apache.thrift.TEnum {
   MINOR(0),
   MERGE(1),
   MAJOR(2),


[25/25] accumulo git commit: Merge branch '1.7'

Posted by ct...@apache.org.
Merge branch '1.7'


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

Branch: refs/heads/master
Commit: a03f14a5cafb0dd2929d84a92766d223a0429e51
Parents: ae4fd48 4d1acd1
Author: Christopher Tubbs <ct...@apache.org>
Authored: Thu Apr 30 13:43:16 2015 -0400
Committer: Christopher Tubbs <ct...@apache.org>
Committed: Thu Apr 30 13:43:16 2015 -0400

----------------------------------------------------------------------
 core/src/main/scripts/generate-thrift.sh | 6 +++---
 pom.xml                                  | 6 ++++--
 2 files changed, 7 insertions(+), 5 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/a03f14a5/pom.xml
----------------------------------------------------------------------


[02/25] accumulo git commit: ACCUMULO-3759 More Java 8 compiler warnings

Posted by ct...@apache.org.
ACCUMULO-3759 More Java 8 compiler warnings

* Fix compiler warnings in Java 8 for 1.5 branch


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

Branch: refs/heads/master
Commit: e395bc8ced5d740fe4a6e5d3ebb169335f64c044
Parents: 5ac1b52
Author: Christopher Tubbs <ct...@apache.org>
Authored: Thu Apr 30 12:04:50 2015 -0400
Committer: Christopher Tubbs <ct...@apache.org>
Committed: Thu Apr 30 12:04:50 2015 -0400

----------------------------------------------------------------------
 .../core/iterators/AggregatingIterator.java       | 18 ++++++++++--------
 .../aggregation/conf/AggregatorConfiguration.java |  3 +--
 .../iterators/aggregation/conf/AggregatorSet.java |  7 +++----
 .../util/shell/commands/AddSplitsCommand.java     | 18 +++++++++++++-----
 .../core/iterators/AggregatingIteratorTest.java   |  6 ++++--
 .../conf/AggregatorConfigurationTest.java         | 13 ++++++++-----
 .../org/apache/accumulo/server/master/Master.java | 16 ++++++++--------
 .../classloader/vfs/AccumuloVFSClassLoader.java   |  6 +++---
 8 files changed, 50 insertions(+), 37 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/e395bc8c/core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java b/core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java
index 28acc2b..13b2710 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java
@@ -27,7 +27,6 @@ import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.data.PartialKey;
 import org.apache.accumulo.core.data.Range;
 import org.apache.accumulo.core.data.Value;
-import org.apache.accumulo.core.iterators.aggregation.Aggregator;
 import org.apache.accumulo.core.iterators.conf.ColumnToClassMapping;
 import org.apache.accumulo.start.classloader.vfs.AccumuloVFSClassLoader;
 import org.apache.log4j.Logger;
@@ -42,7 +41,7 @@ import org.apache.log4j.Logger;
 public class AggregatingIterator implements SortedKeyValueIterator<Key,Value>, OptionDescriber {
 
   private SortedKeyValueIterator<Key,Value> iterator;
-  private ColumnToClassMapping<Aggregator> aggregators;
+  private ColumnToClassMapping<org.apache.accumulo.core.iterators.aggregation.Aggregator> aggregators;
 
   private Key workKey = new Key();
 
@@ -51,6 +50,7 @@ public class AggregatingIterator implements SortedKeyValueIterator<Key,Value>, O
   // private boolean propogateDeletes;
   private static final Logger log = Logger.getLogger(AggregatingIterator.class);
 
+  @Override
   public AggregatingIterator deepCopy(IteratorEnvironment env) {
     return new AggregatingIterator(this, env);
   }
@@ -62,7 +62,7 @@ public class AggregatingIterator implements SortedKeyValueIterator<Key,Value>, O
 
   public AggregatingIterator() {}
 
-  private void aggregateRowColumn(Aggregator aggr) throws IOException {
+  private void aggregateRowColumn(org.apache.accumulo.core.iterators.aggregation.Aggregator aggr) throws IOException {
     // this function assumes that first value is not delete
 
     if (iterator.getTopKey().isDeleted())
@@ -90,14 +90,15 @@ public class AggregatingIterator implements SortedKeyValueIterator<Key,Value>, O
   private void findTop() throws IOException {
     // check if aggregation is needed
     if (iterator.hasTop()) {
-      Aggregator aggr = aggregators.getObject(iterator.getTopKey());
+      org.apache.accumulo.core.iterators.aggregation.Aggregator aggr = aggregators.getObject(iterator.getTopKey());
       if (aggr != null) {
         aggregateRowColumn(aggr);
       }
     }
   }
 
-  public AggregatingIterator(SortedKeyValueIterator<Key,Value> iterator, ColumnToClassMapping<Aggregator> aggregators) throws IOException {
+  public AggregatingIterator(SortedKeyValueIterator<Key,Value> iterator,
+      ColumnToClassMapping<org.apache.accumulo.core.iterators.aggregation.Aggregator> aggregators) throws IOException {
     this.iterator = iterator;
     this.aggregators = aggregators;
   }
@@ -167,7 +168,8 @@ public class AggregatingIterator implements SortedKeyValueIterator<Key,Value>, O
     this.iterator = source;
 
     try {
-      this.aggregators = new ColumnToClassMapping<Aggregator>(options, Aggregator.class);
+      this.aggregators = new ColumnToClassMapping<org.apache.accumulo.core.iterators.aggregation.Aggregator>(options,
+          org.apache.accumulo.core.iterators.aggregation.Aggregator.class);
     } catch (ClassNotFoundException e) {
       log.error(e.toString());
       throw new IllegalArgumentException(e);
@@ -192,9 +194,9 @@ public class AggregatingIterator implements SortedKeyValueIterator<Key,Value>, O
       String classname = entry.getValue();
       if (classname == null)
         throw new IllegalArgumentException("classname null");
-      Class<? extends Aggregator> clazz;
+      Class<? extends org.apache.accumulo.core.iterators.aggregation.Aggregator> clazz;
       try {
-        clazz = AccumuloVFSClassLoader.loadClass(classname, Aggregator.class);
+        clazz = AccumuloVFSClassLoader.loadClass(classname, org.apache.accumulo.core.iterators.aggregation.Aggregator.class);
         clazz.newInstance();
       } catch (ClassNotFoundException e) {
         throw new IllegalArgumentException("class not found: " + classname);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/e395bc8c/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfiguration.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfiguration.java b/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfiguration.java
index 41c0374..3432cf5 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfiguration.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfiguration.java
@@ -16,14 +16,13 @@
  */
 package org.apache.accumulo.core.iterators.aggregation.conf;
 
-import org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig;
 import org.apache.hadoop.io.Text;
 
 /**
  * @deprecated since 1.4
  */
 @Deprecated
-public class AggregatorConfiguration extends PerColumnIteratorConfig {
+public class AggregatorConfiguration extends org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig {
 
   public AggregatorConfiguration(Text columnFamily, String aggClassName) {
     super(columnFamily, aggClassName);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/e395bc8c/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorSet.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorSet.java b/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorSet.java
index 26e2f11..37798b0 100644
--- a/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorSet.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorSet.java
@@ -19,23 +19,22 @@ package org.apache.accumulo.core.iterators.aggregation.conf;
 import java.util.Map;
 
 import org.apache.accumulo.core.data.Key;
-import org.apache.accumulo.core.iterators.aggregation.Aggregator;
 import org.apache.accumulo.core.iterators.conf.ColumnToClassMapping;
 
 /**
  * @deprecated since 1.4
  */
 @Deprecated
-public class AggregatorSet extends ColumnToClassMapping<Aggregator> {
+public class AggregatorSet extends ColumnToClassMapping<org.apache.accumulo.core.iterators.aggregation.Aggregator> {
   public AggregatorSet(Map<String,String> opts) throws InstantiationException, IllegalAccessException, ClassNotFoundException {
-    super(opts, Aggregator.class);
+    super(opts, org.apache.accumulo.core.iterators.aggregation.Aggregator.class);
   }
 
   public AggregatorSet() {
     super();
   }
 
-  public Aggregator getAggregator(Key k) {
+  public org.apache.accumulo.core.iterators.aggregation.Aggregator getAggregator(Key k) {
     return getObject(k);
   }
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/e395bc8c/core/src/main/java/org/apache/accumulo/core/util/shell/commands/AddSplitsCommand.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/util/shell/commands/AddSplitsCommand.java b/core/src/main/java/org/apache/accumulo/core/util/shell/commands/AddSplitsCommand.java
index 3eab0a1..c88171a 100644
--- a/core/src/main/java/org/apache/accumulo/core/util/shell/commands/AddSplitsCommand.java
+++ b/core/src/main/java/org/apache/accumulo/core/util/shell/commands/AddSplitsCommand.java
@@ -34,6 +34,7 @@ import org.apache.hadoop.io.Text;
 public class AddSplitsCommand extends Command {
   private Option optSplitsFile, base64Opt;
 
+  @Override
   public int execute(final String fullCommand, final CommandLine cl, final Shell shellState) throws Exception {
     final String tableName = OptUtil.getTableOpt(cl, shellState);
     final boolean decode = cl.hasOption(base64Opt.getOpt());
@@ -44,11 +45,18 @@ public class AddSplitsCommand extends Command {
       final String f = cl.getOptionValue(optSplitsFile.getOpt());
 
       String line;
-      java.util.Scanner file = new java.util.Scanner(new File(f), UTF_8.name());
-      while (file.hasNextLine()) {
-        line = file.nextLine();
-        if (!line.isEmpty()) {
-          splits.add(decode ? new Text(Base64.decodeBase64(line.getBytes(UTF_8))) : new Text(line));
+      java.util.Scanner file = null;
+      try {
+        file = new java.util.Scanner(new File(f), UTF_8.name());
+        while (file.hasNextLine()) {
+          line = file.nextLine();
+          if (!line.isEmpty()) {
+            splits.add(decode ? new Text(Base64.decodeBase64(line.getBytes(UTF_8))) : new Text(line));
+          }
+        }
+      } finally {
+        if (file != null) {
+          file.close();
         }
       }
     } else {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/e395bc8c/core/src/test/java/org/apache/accumulo/core/iterators/AggregatingIteratorTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/iterators/AggregatingIteratorTest.java b/core/src/test/java/org/apache/accumulo/core/iterators/AggregatingIteratorTest.java
index 788366a..f1918b4 100644
--- a/core/src/test/java/org/apache/accumulo/core/iterators/AggregatingIteratorTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/iterators/AggregatingIteratorTest.java
@@ -31,7 +31,6 @@ import org.apache.accumulo.core.data.ByteSequence;
 import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.data.Range;
 import org.apache.accumulo.core.data.Value;
-import org.apache.accumulo.core.iterators.aggregation.Aggregator;
 import org.apache.accumulo.core.iterators.system.MultiIterator;
 import org.apache.hadoop.io.Text;
 
@@ -43,20 +42,23 @@ public class AggregatingIteratorTest extends TestCase {
 
   private static final Collection<ByteSequence> EMPTY_COL_FAMS = new ArrayList<ByteSequence>();
 
-  public static class SummationAggregator implements Aggregator {
+  public static class SummationAggregator implements org.apache.accumulo.core.iterators.aggregation.Aggregator {
 
     int sum;
 
+    @Override
     public Value aggregate() {
       return new Value((sum + "").getBytes());
     }
 
+    @Override
     public void collect(Value value) {
       int val = Integer.parseInt(value.toString());
 
       sum += val;
     }
 
+    @Override
     public void reset() {
       sum = 0;
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/e395bc8c/core/src/test/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfigurationTest.java
----------------------------------------------------------------------
diff --git a/core/src/test/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfigurationTest.java b/core/src/test/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfigurationTest.java
index 1a285bc..6d666a3 100644
--- a/core/src/test/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfigurationTest.java
+++ b/core/src/test/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorConfigurationTest.java
@@ -18,7 +18,6 @@ package org.apache.accumulo.core.iterators.aggregation.conf;
 
 import junit.framework.TestCase;
 
-import org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig;
 import org.apache.hadoop.io.Text;
 
 /**
@@ -46,18 +45,22 @@ public class AggregatorConfigurationTest extends TestCase {
 
   private void runTest(Text colf) {
     String encodedCols;
-    PerColumnIteratorConfig ac3 = new PerColumnIteratorConfig(colf, "com.foo.SuperAgg");
+    org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig ac3 = new org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig(colf,
+        "com.foo.SuperAgg");
     encodedCols = ac3.encodeColumns();
-    PerColumnIteratorConfig ac4 = PerColumnIteratorConfig.decodeColumns(encodedCols, "com.foo.SuperAgg");
+    org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig ac4 = org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig.decodeColumns(
+        encodedCols, "com.foo.SuperAgg");
 
     assertEquals(colf, ac4.getColumnFamily());
     assertNull(ac4.getColumnQualifier());
   }
 
   private void runTest(Text colf, Text colq) {
-    PerColumnIteratorConfig ac = new PerColumnIteratorConfig(colf, colq, "com.foo.SuperAgg");
+    org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig ac = new org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig(colf, colq,
+        "com.foo.SuperAgg");
     String encodedCols = ac.encodeColumns();
-    PerColumnIteratorConfig ac2 = PerColumnIteratorConfig.decodeColumns(encodedCols, "com.foo.SuperAgg");
+    org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig ac2 = org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig.decodeColumns(
+        encodedCols, "com.foo.SuperAgg");
 
     assertEquals(colf, ac2.getColumnFamily());
     assertEquals(colq, ac2.getColumnQualifier());

http://git-wip-us.apache.org/repos/asf/accumulo/blob/e395bc8c/server/src/main/java/org/apache/accumulo/server/master/Master.java
----------------------------------------------------------------------
diff --git a/server/src/main/java/org/apache/accumulo/server/master/Master.java b/server/src/main/java/org/apache/accumulo/server/master/Master.java
index 61ba7cf..dd94683 100644
--- a/server/src/main/java/org/apache/accumulo/server/master/Master.java
+++ b/server/src/main/java/org/apache/accumulo/server/master/Master.java
@@ -230,17 +230,17 @@ public class Master implements LiveTServerSet.Listener, TableObserver, CurrentSt
   }
 
   static final boolean X = true;
-  static final boolean _ = false;
+  static final boolean O = false;
   // @formatter:off
   static final boolean transitionOK[][] = {
       //                              INITIAL HAVE_LOCK SAFE_MODE NORMAL UNLOAD_META UNLOAD_ROOT STOP
-      /* INITIAL */                   {X,     X,        _,        _,      _,         _,          X},
-      /* HAVE_LOCK */                 {_,     X,        X,        X,      _,         _,          X},
-      /* SAFE_MODE */                 {_,     _,        X,        X,      X,         _,          X},
-      /* NORMAL */                    {_,     _,        X,        X,      X,         _,          X},
-      /* UNLOAD_METADATA_TABLETS */   {_,     _,        X,        X,      X,         X,          X},
-      /* UNLOAD_ROOT_TABLET */        {_,     _,        _,        X,      _,         X,          X},
-      /* STOP */                      {_,     _,        _,        _,      _,         _,          X}};
+      /* INITIAL */                   {X,     X,        O,        O,      O,         O,          X},
+      /* HAVE_LOCK */                 {O,     X,        X,        X,      O,         O,          X},
+      /* SAFE_MODE */                 {O,     O,        X,        X,      X,         O,          X},
+      /* NORMAL */                    {O,     O,        X,        X,      X,         O,          X},
+      /* UNLOAD_METADATA_TABLETS */   {O,     O,        X,        X,      X,         X,          X},
+      /* UNLOAD_ROOT_TABLET */        {O,     O,        O,        X,      O,         X,          X},
+      /* STOP */                      {O,     O,        O,        O,      O,         O,          X}};
   //@formatter:on
   synchronized private void setMasterState(MasterState newState) {
     if (state.equals(newState))

http://git-wip-us.apache.org/repos/asf/accumulo/blob/e395bc8c/start/src/main/java/org/apache/accumulo/start/classloader/vfs/AccumuloVFSClassLoader.java
----------------------------------------------------------------------
diff --git a/start/src/main/java/org/apache/accumulo/start/classloader/vfs/AccumuloVFSClassLoader.java b/start/src/main/java/org/apache/accumulo/start/classloader/vfs/AccumuloVFSClassLoader.java
index 7fa17d6..0abc79a 100644
--- a/start/src/main/java/org/apache/accumulo/start/classloader/vfs/AccumuloVFSClassLoader.java
+++ b/start/src/main/java/org/apache/accumulo/start/classloader/vfs/AccumuloVFSClassLoader.java
@@ -62,6 +62,7 @@ public class AccumuloVFSClassLoader {
 
   public static class AccumuloVFSClassLoaderShutdownThread implements Runnable {
 
+    @Override
     public void run() {
       try {
         AccumuloVFSClassLoader.close();
@@ -100,7 +101,7 @@ public class AccumuloVFSClassLoader {
 
   public synchronized static <U> Class<? extends U> loadClass(String classname, Class<U> extension) throws ClassNotFoundException {
     try {
-      return (Class<? extends U>) getClassLoader().loadClass(classname).asSubclass(extension);
+      return getClassLoader().loadClass(classname).asSubclass(extension);
     } catch (IOException e) {
       throw new ClassNotFoundException("IO Error loading class " + classname, e);
     }
@@ -326,10 +327,9 @@ public class AccumuloVFSClassLoader {
 
         if (classLoader instanceof URLClassLoader) {
           // If VFS class loader enabled, but no contexts defined.
-          URLClassLoader ucl = (URLClassLoader) classLoader;
           out.print("Level " + classLoaderDescription + " URL classpath items are:");
 
-          for (URL u : ucl.getURLs()) {
+          for (URL u : ((URLClassLoader) classLoader).getURLs()) {
             out.print("\t" + u.toExternalForm());
           }
 


[07/25] accumulo git commit: Merge branch '1.5' into 1.6

Posted by ct...@apache.org.
Merge branch '1.5' into 1.6

Conflicts:
	core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java
	core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorSet.java
	server/src/main/java/org/apache/accumulo/server/master/Master.java


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

Branch: refs/heads/1.6
Commit: b636ff2cc614f8112207d369acd38a83770397e3
Parents: 67c8b2b e395bc8
Author: Christopher Tubbs <ct...@apache.org>
Authored: Thu Apr 30 12:10:44 2015 -0400
Committer: Christopher Tubbs <ct...@apache.org>
Committed: Thu Apr 30 12:10:44 2015 -0400

----------------------------------------------------------------------
 .../core/iterators/AggregatingIterator.java       | 18 ++++++++++--------
 .../aggregation/conf/AggregatorConfiguration.java |  3 +--
 .../iterators/aggregation/conf/AggregatorSet.java |  7 +++----
 .../util/shell/commands/AddSplitsCommand.java     | 17 ++++++++++++-----
 .../core/iterators/AggregatingIteratorTest.java   |  6 ++++--
 .../conf/AggregatorConfigurationTest.java         | 13 ++++++++-----
 6 files changed, 38 insertions(+), 26 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/b636ff2c/core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java
----------------------------------------------------------------------
diff --cc core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java
index fd5525b,13b2710..eb45fac
--- a/core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java
@@@ -168,10 -168,8 +169,11 @@@ public class AggregatingIterator implem
      this.iterator = source;
  
      try {
 +      String context = null;
 +      if (null != env)
 +        context = env.getConfig().get(Property.TABLE_CLASSPATH);
-       this.aggregators = new ColumnToClassMapping<Aggregator>(options, Aggregator.class, context);
+       this.aggregators = new ColumnToClassMapping<org.apache.accumulo.core.iterators.aggregation.Aggregator>(options,
 -          org.apache.accumulo.core.iterators.aggregation.Aggregator.class);
++          org.apache.accumulo.core.iterators.aggregation.Aggregator.class, context);
      } catch (ClassNotFoundException e) {
        log.error(e.toString());
        throw new IllegalArgumentException(e);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b636ff2c/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorSet.java
----------------------------------------------------------------------
diff --cc core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorSet.java
index c874cc8,37798b0..d6545ac
--- a/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorSet.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorSet.java
@@@ -27,9 -25,9 +26,9 @@@ import org.apache.accumulo.core.iterato
   * @deprecated since 1.4
   */
  @Deprecated
- public class AggregatorSet extends ColumnToClassMapping<Aggregator> {
+ public class AggregatorSet extends ColumnToClassMapping<org.apache.accumulo.core.iterators.aggregation.Aggregator> {
 -  public AggregatorSet(Map<String,String> opts) throws InstantiationException, IllegalAccessException, ClassNotFoundException {
 +  public AggregatorSet(Map<String,String> opts) throws InstantiationException, IllegalAccessException, ClassNotFoundException, IOException {
-     super(opts, Aggregator.class);
+     super(opts, org.apache.accumulo.core.iterators.aggregation.Aggregator.class);
    }
  
    public AggregatorSet() {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b636ff2c/core/src/main/java/org/apache/accumulo/core/util/shell/commands/AddSplitsCommand.java
----------------------------------------------------------------------
diff --cc core/src/main/java/org/apache/accumulo/core/util/shell/commands/AddSplitsCommand.java
index efbbcbe,c88171a..18298dd
--- a/core/src/main/java/org/apache/accumulo/core/util/shell/commands/AddSplitsCommand.java
+++ b/core/src/main/java/org/apache/accumulo/core/util/shell/commands/AddSplitsCommand.java
@@@ -45,14 -45,20 +45,21 @@@ public class AddSplitsCommand extends C
        final String f = cl.getOptionValue(optSplitsFile.getOpt());
  
        String line;
-       java.util.Scanner file = new java.util.Scanner(new File(f), UTF_8.name());
-       while (file.hasNextLine()) {
-         line = file.nextLine();
-         if (!line.isEmpty()) {
-           splits.add(decode ? new Text(Base64.decodeBase64(line.getBytes(UTF_8))) : new Text(line));
+       java.util.Scanner file = null;
+       try {
+         file = new java.util.Scanner(new File(f), UTF_8.name());
+         while (file.hasNextLine()) {
+           line = file.nextLine();
+           if (!line.isEmpty()) {
+             splits.add(decode ? new Text(Base64.decodeBase64(line.getBytes(UTF_8))) : new Text(line));
+           }
+         }
+       } finally {
+         if (file != null) {
+           file.close();
          }
        }
 +      file.close();
      } else {
        if (cl.getArgList().isEmpty()) {
          throw new MissingArgumentException("No split points specified");


[06/25] accumulo git commit: Merge branch '1.5' into 1.6

Posted by ct...@apache.org.
Merge branch '1.5' into 1.6

Conflicts:
	core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java
	core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorSet.java
	server/src/main/java/org/apache/accumulo/server/master/Master.java


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

Branch: refs/heads/master
Commit: b636ff2cc614f8112207d369acd38a83770397e3
Parents: 67c8b2b e395bc8
Author: Christopher Tubbs <ct...@apache.org>
Authored: Thu Apr 30 12:10:44 2015 -0400
Committer: Christopher Tubbs <ct...@apache.org>
Committed: Thu Apr 30 12:10:44 2015 -0400

----------------------------------------------------------------------
 .../core/iterators/AggregatingIterator.java       | 18 ++++++++++--------
 .../aggregation/conf/AggregatorConfiguration.java |  3 +--
 .../iterators/aggregation/conf/AggregatorSet.java |  7 +++----
 .../util/shell/commands/AddSplitsCommand.java     | 17 ++++++++++++-----
 .../core/iterators/AggregatingIteratorTest.java   |  6 ++++--
 .../conf/AggregatorConfigurationTest.java         | 13 ++++++++-----
 6 files changed, 38 insertions(+), 26 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/b636ff2c/core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java
----------------------------------------------------------------------
diff --cc core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java
index fd5525b,13b2710..eb45fac
--- a/core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/AggregatingIterator.java
@@@ -168,10 -168,8 +169,11 @@@ public class AggregatingIterator implem
      this.iterator = source;
  
      try {
 +      String context = null;
 +      if (null != env)
 +        context = env.getConfig().get(Property.TABLE_CLASSPATH);
-       this.aggregators = new ColumnToClassMapping<Aggregator>(options, Aggregator.class, context);
+       this.aggregators = new ColumnToClassMapping<org.apache.accumulo.core.iterators.aggregation.Aggregator>(options,
 -          org.apache.accumulo.core.iterators.aggregation.Aggregator.class);
++          org.apache.accumulo.core.iterators.aggregation.Aggregator.class, context);
      } catch (ClassNotFoundException e) {
        log.error(e.toString());
        throw new IllegalArgumentException(e);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b636ff2c/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorSet.java
----------------------------------------------------------------------
diff --cc core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorSet.java
index c874cc8,37798b0..d6545ac
--- a/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorSet.java
+++ b/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/conf/AggregatorSet.java
@@@ -27,9 -25,9 +26,9 @@@ import org.apache.accumulo.core.iterato
   * @deprecated since 1.4
   */
  @Deprecated
- public class AggregatorSet extends ColumnToClassMapping<Aggregator> {
+ public class AggregatorSet extends ColumnToClassMapping<org.apache.accumulo.core.iterators.aggregation.Aggregator> {
 -  public AggregatorSet(Map<String,String> opts) throws InstantiationException, IllegalAccessException, ClassNotFoundException {
 +  public AggregatorSet(Map<String,String> opts) throws InstantiationException, IllegalAccessException, ClassNotFoundException, IOException {
-     super(opts, Aggregator.class);
+     super(opts, org.apache.accumulo.core.iterators.aggregation.Aggregator.class);
    }
  
    public AggregatorSet() {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/b636ff2c/core/src/main/java/org/apache/accumulo/core/util/shell/commands/AddSplitsCommand.java
----------------------------------------------------------------------
diff --cc core/src/main/java/org/apache/accumulo/core/util/shell/commands/AddSplitsCommand.java
index efbbcbe,c88171a..18298dd
--- a/core/src/main/java/org/apache/accumulo/core/util/shell/commands/AddSplitsCommand.java
+++ b/core/src/main/java/org/apache/accumulo/core/util/shell/commands/AddSplitsCommand.java
@@@ -45,14 -45,20 +45,21 @@@ public class AddSplitsCommand extends C
        final String f = cl.getOptionValue(optSplitsFile.getOpt());
  
        String line;
-       java.util.Scanner file = new java.util.Scanner(new File(f), UTF_8.name());
-       while (file.hasNextLine()) {
-         line = file.nextLine();
-         if (!line.isEmpty()) {
-           splits.add(decode ? new Text(Base64.decodeBase64(line.getBytes(UTF_8))) : new Text(line));
+       java.util.Scanner file = null;
+       try {
+         file = new java.util.Scanner(new File(f), UTF_8.name());
+         while (file.hasNextLine()) {
+           line = file.nextLine();
+           if (!line.isEmpty()) {
+             splits.add(decode ? new Text(Base64.decodeBase64(line.getBytes(UTF_8))) : new Text(line));
+           }
+         }
+       } finally {
+         if (file != null) {
+           file.close();
          }
        }
 +      file.close();
      } else {
        if (cl.getArgList().isEmpty()) {
          throw new MissingArgumentException("No split points specified");


[09/25] accumulo git commit: ACCUMULO-3759 More build warnings on Java 8

Posted by ct...@apache.org.
http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloProxy.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloProxy.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloProxy.java
index 3b23175..b22da8f 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloProxy.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloProxy.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class AccumuloProxy {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class AccumuloProxy {
 
   public interface Iface {
 
@@ -12719,7 +12719,7 @@ import org.slf4j.LoggerFactory;
     public Map<String,String> loginProperties; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       PRINCIPAL((short)1, "principal"),
       LOGIN_PROPERTIES((short)2, "loginProperties");
 
@@ -13225,7 +13225,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH2((short)1, "ouch2");
 
@@ -13694,7 +13694,7 @@ import org.slf4j.LoggerFactory;
     public String constraintClassName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       CONSTRAINT_CLASS_NAME((short)3, "constraintClassName");
@@ -14261,7 +14261,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -14919,7 +14919,7 @@ import org.slf4j.LoggerFactory;
     public Set<ByteBuffer> splits; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       SPLITS((short)3, "splits");
@@ -15533,7 +15533,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -16095,7 +16095,7 @@ import org.slf4j.LoggerFactory;
     public Set<IteratorScope> scopes; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       SETTING((short)3, "setting"),
@@ -16815,7 +16815,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -17377,7 +17377,7 @@ import org.slf4j.LoggerFactory;
     public Set<IteratorScope> scopes; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       SETTING((short)3, "setting"),
@@ -18097,7 +18097,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -18655,7 +18655,7 @@ import org.slf4j.LoggerFactory;
     public String tableName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName");
 
@@ -19118,7 +19118,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch1; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -19484,7 +19484,7 @@ import org.slf4j.LoggerFactory;
     public Set<String> propertiesToExclude; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       NEW_TABLE_NAME((short)3, "newTableName"),
@@ -20444,7 +20444,7 @@ import org.slf4j.LoggerFactory;
     public TableExistsException ouch4; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3"),
@@ -21112,7 +21112,7 @@ import org.slf4j.LoggerFactory;
     public boolean wait; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       START_ROW((short)3, "startRow"),
@@ -22137,7 +22137,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -22695,7 +22695,7 @@ import org.slf4j.LoggerFactory;
     public String tableName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName");
 
@@ -23162,7 +23162,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -23728,7 +23728,7 @@ import org.slf4j.LoggerFactory;
     public TimeType type; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       VERSIONING_ITER((short)3, "versioningIter"),
@@ -24401,7 +24401,7 @@ import org.slf4j.LoggerFactory;
     public TableExistsException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -24959,7 +24959,7 @@ import org.slf4j.LoggerFactory;
     public String tableName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName");
 
@@ -25426,7 +25426,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -25988,7 +25988,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer endRow; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       START_ROW((short)3, "startRow"),
@@ -26673,7 +26673,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -27233,7 +27233,7 @@ import org.slf4j.LoggerFactory;
     public String exportDir; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       EXPORT_DIR((short)3, "exportDir");
@@ -27798,7 +27798,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -28362,7 +28362,7 @@ import org.slf4j.LoggerFactory;
     public boolean wait; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       START_ROW((short)3, "startRow"),
@@ -29143,7 +29143,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -29701,7 +29701,7 @@ import org.slf4j.LoggerFactory;
     public Set<String> tables; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLES((short)2, "tables");
 
@@ -30219,7 +30219,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -30929,7 +30929,7 @@ import org.slf4j.LoggerFactory;
     public String tableName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName");
 
@@ -31398,7 +31398,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -32158,7 +32158,7 @@ import org.slf4j.LoggerFactory;
     public IteratorScope scope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       ITERATOR_NAME((short)3, "iteratorName"),
@@ -32835,7 +32835,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -33506,7 +33506,7 @@ import org.slf4j.LoggerFactory;
     public boolean endInclusive; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       AUTHS((short)3, "auths"),
@@ -34528,7 +34528,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -35195,7 +35195,7 @@ import org.slf4j.LoggerFactory;
     public String tableName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName");
 
@@ -35664,7 +35664,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -36378,7 +36378,7 @@ import org.slf4j.LoggerFactory;
     public boolean setTime; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       IMPORT_DIR((short)3, "importDir"),
@@ -37137,7 +37137,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch4; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH3((short)2, "ouch3"),
       OUCH4((short)3, "ouch4");
@@ -37697,7 +37697,7 @@ import org.slf4j.LoggerFactory;
     public String importDir; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       IMPORT_DIR((short)3, "importDir");
@@ -38262,7 +38262,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -38822,7 +38822,7 @@ import org.slf4j.LoggerFactory;
     public int maxSplits; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       MAX_SPLITS((short)3, "maxSplits");
@@ -39387,7 +39387,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -40090,7 +40090,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer login; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -40455,7 +40455,7 @@ import org.slf4j.LoggerFactory;
     public Set<String> success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -40860,7 +40860,7 @@ import org.slf4j.LoggerFactory;
     public String tableName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName");
 
@@ -41329,7 +41329,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -42084,7 +42084,7 @@ import org.slf4j.LoggerFactory;
     public String tableName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName");
 
@@ -42553,7 +42553,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -43265,7 +43265,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer endRow; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       START_ROW((short)3, "startRow"),
@@ -43950,7 +43950,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -44510,7 +44510,7 @@ import org.slf4j.LoggerFactory;
     public boolean wait; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       WAIT((short)3, "wait");
@@ -45075,7 +45075,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -45635,7 +45635,7 @@ import org.slf4j.LoggerFactory;
     public boolean wait; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       WAIT((short)3, "wait");
@@ -46200,7 +46200,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -46760,7 +46760,7 @@ import org.slf4j.LoggerFactory;
     public int constraint; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       CONSTRAINT((short)3, "constraint");
@@ -47323,7 +47323,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -47885,7 +47885,7 @@ import org.slf4j.LoggerFactory;
     public Set<IteratorScope> scopes; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       ITER_NAME((short)3, "iterName"),
@@ -48600,7 +48600,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -49160,7 +49160,7 @@ import org.slf4j.LoggerFactory;
     public String property; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       PROPERTY((short)3, "property");
@@ -49725,7 +49725,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -50285,7 +50285,7 @@ import org.slf4j.LoggerFactory;
     public String newTableName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       OLD_TABLE_NAME((short)2, "oldTableName"),
       NEW_TABLE_NAME((short)3, "newTableName");
@@ -50852,7 +50852,7 @@ import org.slf4j.LoggerFactory;
     public TableExistsException ouch4; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3"),
@@ -51512,7 +51512,7 @@ import org.slf4j.LoggerFactory;
     public Map<String,Set<String>> groups; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       GROUPS((short)3, "groups");
@@ -52173,7 +52173,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -52735,7 +52735,7 @@ import org.slf4j.LoggerFactory;
     public String value; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       PROPERTY((short)3, "property"),
@@ -53398,7 +53398,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -53960,7 +53960,7 @@ import org.slf4j.LoggerFactory;
     public int maxSplits; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       RANGE((short)3, "range"),
@@ -54628,7 +54628,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -55338,7 +55338,7 @@ import org.slf4j.LoggerFactory;
     public String tableName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName");
 
@@ -55801,7 +55801,7 @@ import org.slf4j.LoggerFactory;
     public boolean success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -56155,7 +56155,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer login; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -56520,7 +56520,7 @@ import org.slf4j.LoggerFactory;
     public Map<String,String> success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -56932,7 +56932,7 @@ import org.slf4j.LoggerFactory;
     public String asTypeName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       CLASS_NAME((short)3, "className"),
@@ -57597,7 +57597,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -58253,7 +58253,7 @@ import org.slf4j.LoggerFactory;
     public String tserver; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TSERVER((short)2, "tserver");
 
@@ -58718,7 +58718,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
 
@@ -59176,7 +59176,7 @@ import org.slf4j.LoggerFactory;
     public String tserver; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TSERVER((short)2, "tserver");
 
@@ -59643,7 +59643,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
@@ -60253,7 +60253,7 @@ import org.slf4j.LoggerFactory;
     public String tserver; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TSERVER((short)2, "tserver");
 
@@ -60720,7 +60720,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
@@ -61328,7 +61328,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer login; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -61697,7 +61697,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
@@ -62303,7 +62303,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer login; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -62672,7 +62672,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
@@ -63278,7 +63278,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer login; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -63643,7 +63643,7 @@ import org.slf4j.LoggerFactory;
     public List<String> success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -64048,7 +64048,7 @@ import org.slf4j.LoggerFactory;
     public String property; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       PROPERTY((short)2, "property");
 
@@ -64513,7 +64513,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
 
@@ -64973,7 +64973,7 @@ import org.slf4j.LoggerFactory;
     public String value; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       PROPERTY((short)2, "property"),
       VALUE((short)3, "value");
@@ -65536,7 +65536,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
 
@@ -65996,7 +65996,7 @@ import org.slf4j.LoggerFactory;
     public String asTypeName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       CLASS_NAME((short)2, "className"),
       AS_TYPE_NAME((short)3, "asTypeName");
@@ -66561,7 +66561,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
@@ -67119,7 +67119,7 @@ import org.slf4j.LoggerFactory;
     public Map<String,String> properties; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       USER((short)2, "user"),
       PROPERTIES((short)3, "properties");
@@ -67736,7 +67736,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
@@ -68294,7 +68294,7 @@ import org.slf4j.LoggerFactory;
     public Set<ByteBuffer> authorizations; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       USER((short)2, "user"),
       AUTHORIZATIONS((short)3, "authorizations");
@@ -68906,7 +68906,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
 
@@ -69366,7 +69366,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer password; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       USER((short)2, "user"),
       PASSWORD((short)3, "password");
@@ -69940,7 +69940,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
 
@@ -70400,7 +70400,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer password; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       USER((short)2, "user"),
       PASSWORD((short)3, "password");
@@ -70974,7 +70974,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
 
@@ -71432,7 +71432,7 @@ import org.slf4j.LoggerFactory;
     public String user; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       USER((short)2, "user");
 
@@ -71897,7 +71897,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
 
@@ -72355,7 +72355,7 @@ import org.slf4j.LoggerFactory;
     public String user; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       USER((short)2, "user");
 
@@ -72822,7 +72822,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
@@ -73433,7 +73433,7 @@ import org.slf4j.LoggerFactory;
     public SystemPermission perm; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       USER((short)2, "user"),
       /**
@@ -74008,7 +74008,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
 
@@ -74474,7 +74474,7 @@ import org.slf4j.LoggerFactory;
     public TablePermission perm; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       USER((short)2, "user"),
       TABLE((short)3, "table"),
@@ -75149,7 +75149,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -75713,7 +75713,7 @@ import org.slf4j.LoggerFactory;
     public SystemPermission perm; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       USER((short)2, "user"),
       /**
@@ -76290,7 +76290,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
@@ -76854,7 +76854,7 @@ import org.slf4j.LoggerFactory;
     public TablePermission perm; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       USER((short)2, "user"),
       TABLE((short)3, "table"),
@@ -77531,7 +77531,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -78185,7 +78185,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer login; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -78556,7 +78556,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -79267,7 +79267,7 @@ import org.slf4j.LoggerFactory;
     public SystemPermission perm; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       USER((short)2, "user"),
       /**
@@ -79842,7 +79842,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
 
@@ -80308,7 +80308,7 @@ import org.slf4j.LoggerFactory;
     public TablePermission perm; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       USER((short)2, "user"),
       TABLE((short)3, "table"),
@@ -80983,7 +80983,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -81543,7 +81543,7 @@ import org.slf4j.LoggerFactory;
     public BatchScanOptions options; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       OPTIONS((short)3, "options");
@@ -82115,7 +82115,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -82773,7 +82773,7 @@ import org.slf4j.LoggerFactory;
     public ScanOptions options; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       OPTIONS((short)3, "options");
@@ -83345,7 +83345,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -83999,7 +83999,7 @@ import org.slf4j.LoggerFactory;
     public String scanner; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SCANNER((short)1, "scanner");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -84355,7 +84355,7 @@ import org.slf4j.LoggerFactory;
     public UnknownScanner ouch1; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1");
 
@@ -84809,7 +84809,7 @@ import org.slf4j.LoggerFactory;
     public String scanner; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SCANNER((short)1, "scanner");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -85169,7 +85169,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -85830,7 +85830,7 @@ import org.slf4j.LoggerFactory;
     public int k; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SCANNER((short)1, "scanner"),
       K((short)2, "k");
 
@@ -86286,7 +86286,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -86945,7 +86945,7 @@ import org.slf4j.LoggerFactory;
     public String scanner; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SCANNER((short)1, "scanner");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -87299,7 +87299,7 @@ import org.slf4j.LoggerFactory;
     public UnknownScanner ouch1; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -87659,7 +87659,7 @@ import org.slf4j.LoggerFactory;
     public Map<ByteBuffer,List<ColumnUpdate>> cells; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       CELLS((short)3, "cells");
@@ -88328,7 +88328,7 @@ import org.slf4j.LoggerFactory;
     public MutationsRejectedException ouch4; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUTCH1((short)1, "outch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3"),
@@ -88988,7 +88988,7 @@ import org.slf4j.LoggerFactory;
     public WriterOptions opts; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       OPTS((short)3, "opts");
@@ -89560,7 +89560,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUTCH1((short)1, "outch1"),
       OUCH2((short)2, "ouch2"),
@@ -90216,7 +90216,7 @@ import org.slf4j.LoggerFactory;
     public Map<ByteBuffer,List<ColumnUpdate>> cells; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       WRITER((short)1, "writer"),
       CELLS((short)2, "cells");
 
@@ -90770,7 +90770,7 @@ import org.slf4j.LoggerFactory;
     public String writer; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       WRITER((short)1, "writer");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -91126,7 +91126,7 @@ import org.slf4j.LoggerFactory;
     public MutationsRejectedException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
 
@@ -91582,7 +91582,7 @@ import org.slf4j.LoggerFactory;
     public String writer; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       WRITER((short)1, "writer");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -91938,7 +91938,7 @@ import org.slf4j.LoggerFactory;
     public MutationsRejectedException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
 
@@ -92400,7 +92400,7 @@ import org.slf4j.LoggerFactory;
     public ConditionalUpdates updates; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       ROW((short)3, "row"),
@@ -93085,7 +93085,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       /**
        * 
        * @see ConditionalStatus
@@ -93755,7 +93755,7 @@ import org.slf4j.LoggerFactory;
     public ConditionalWriterOptions options; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       OPTIONS((short)3, "options");
@@ -94327,7 +94327,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -94983,7 +94983,7 @@ import org.slf4j.LoggerFactory;
     public Map<ByteBuffer,ConditionalUpdates> updates; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       CONDITIONAL_WRITER((short)1, "conditionalWriter"),
       UPDATES((short)2, "updates");
 
@@ -95507,7 +95507,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -96225,7 +96225,7 @@ import org.slf4j.LoggerFactory;
     public String conditionalWriter; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       CONDITIONAL_WRITER((short)1, "conditionalWriter");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -96577,7 +96577,7 @@ import org.slf4j.LoggerFactory;
 
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
 ;
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -96825,7 +96825,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer row; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       ROW((short)1, "row");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -97190,7 +97190,7 @@ import org.slf4j.LoggerFactory;
     public Range success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -97555,7 +97555,7 @@ import org.slf4j.LoggerFactory;
     public PartialKey part; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       KEY((short)1, "key"),
       /**
        * 
@@ -98024,7 +98024,7 @@ import org.slf4j.LoggerFactory;
     public Key success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloSecurityException.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloSecurityException.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloSecurityException.java
index 55e074b..28b1e6c 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloSecurityException.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloSecurityException.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class AccumuloSecurityException extends TException implements org.apache.thrift.TBase<AccumuloSecurityException, AccumuloSecurityException._Fields>, java.io.Serializable, Cloneable, Comparable<AccumuloSecurityException> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class AccumuloSecurityException extends TException implements org.apache.thrift.TBase<AccumuloSecurityException, AccumuloSecurityException._Fields>, java.io.Serializable, Cloneable, Comparable<AccumuloSecurityException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("AccumuloSecurityException");
 
   private static final org.apache.thrift.protocol.TField MSG_FIELD_DESC = new org.apache.thrift.protocol.TField("msg", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public String msg; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     MSG((short)1, "msg");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ActiveCompaction.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ActiveCompaction.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ActiveCompaction.java
index 05de413..58e1321 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ActiveCompaction.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ActiveCompaction.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ActiveCompaction implements org.apache.thrift.TBase<ActiveCompaction, ActiveCompaction._Fields>, java.io.Serializable, Cloneable, Comparable<ActiveCompaction> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ActiveCompaction implements org.apache.thrift.TBase<ActiveCompaction, ActiveCompaction._Fields>, java.io.Serializable, Cloneable, Comparable<ActiveCompaction> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ActiveCompaction");
 
   private static final org.apache.thrift.protocol.TField EXTENT_FIELD_DESC = new org.apache.thrift.protocol.TField("extent", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -88,7 +88,7 @@ import org.slf4j.LoggerFactory;
   public List<IteratorSetting> iterators; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     EXTENT((short)1, "extent"),
     AGE((short)2, "age"),
     INPUT_FILES((short)3, "inputFiles"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ActiveScan.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ActiveScan.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ActiveScan.java
index a34e57f..bc9ad51 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ActiveScan.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ActiveScan.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ActiveScan implements org.apache.thrift.TBase<ActiveScan, ActiveScan._Fields>, java.io.Serializable, Cloneable, Comparable<ActiveScan> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ActiveScan implements org.apache.thrift.TBase<ActiveScan, ActiveScan._Fields>, java.io.Serializable, Cloneable, Comparable<ActiveScan> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ActiveScan");
 
   private static final org.apache.thrift.protocol.TField CLIENT_FIELD_DESC = new org.apache.thrift.protocol.TField("client", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -90,7 +90,7 @@ import org.slf4j.LoggerFactory;
   public List<ByteBuffer> authorizations; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     CLIENT((short)1, "client"),
     USER((short)2, "user"),
     TABLE((short)3, "table"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/BatchScanOptions.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/BatchScanOptions.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/BatchScanOptions.java
index e749ac4..948d822 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/BatchScanOptions.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/BatchScanOptions.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class BatchScanOptions implements org.apache.thrift.TBase<BatchScanOptions, BatchScanOptions._Fields>, java.io.Serializable, Cloneable, Comparable<BatchScanOptions> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class BatchScanOptions implements org.apache.thrift.TBase<BatchScanOptions, BatchScanOptions._Fields>, java.io.Serializable, Cloneable, Comparable<BatchScanOptions> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("BatchScanOptions");
 
   private static final org.apache.thrift.protocol.TField AUTHORIZATIONS_FIELD_DESC = new org.apache.thrift.protocol.TField("authorizations", org.apache.thrift.protocol.TType.SET, (short)1);
@@ -70,7 +70,7 @@ import org.slf4j.LoggerFactory;
   public int threads; // optional
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     AUTHORIZATIONS((short)1, "authorizations"),
     RANGES((short)2, "ranges"),
     COLUMNS((short)3, "columns"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Column.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Column.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Column.java
index 3c20017..007eb53 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Column.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Column.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class Column implements org.apache.thrift.TBase<Column, Column._Fields>, java.io.Serializable, Cloneable, Comparable<Column> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class Column implements org.apache.thrift.TBase<Column, Column._Fields>, java.io.Serializable, Cloneable, Comparable<Column> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("Column");
 
   private static final org.apache.thrift.protocol.TField COL_FAMILY_FIELD_DESC = new org.apache.thrift.protocol.TField("colFamily", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -66,7 +66,7 @@ import org.slf4j.LoggerFactory;
   public ByteBuffer colVisibility; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     COL_FAMILY((short)1, "colFamily"),
     COL_QUALIFIER((short)2, "colQualifier"),
     COL_VISIBILITY((short)3, "colVisibility");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ColumnUpdate.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ColumnUpdate.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ColumnUpdate.java
index a3b040e..97d9542 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ColumnUpdate.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ColumnUpdate.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ColumnUpdate implements org.apache.thrift.TBase<ColumnUpdate, ColumnUpdate._Fields>, java.io.Serializable, Cloneable, Comparable<ColumnUpdate> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ColumnUpdate implements org.apache.thrift.TBase<ColumnUpdate, ColumnUpdate._Fields>, java.io.Serializable, Cloneable, Comparable<ColumnUpdate> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ColumnUpdate");
 
   private static final org.apache.thrift.protocol.TField COL_FAMILY_FIELD_DESC = new org.apache.thrift.protocol.TField("colFamily", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -72,7 +72,7 @@ import org.slf4j.LoggerFactory;
   public boolean deleteCell; // optional
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     COL_FAMILY((short)1, "colFamily"),
     COL_QUALIFIER((short)2, "colQualifier"),
     COL_VISIBILITY((short)3, "colVisibility"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/CompactionReason.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/CompactionReason.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/CompactionReason.java
index 36bc32a..1875275 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/CompactionReason.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/CompactionReason.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum CompactionReason implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum CompactionReason implements org.apache.thrift.TEnum {
   USER(0),
   SYSTEM(1),
   CHOP(2),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/CompactionType.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/CompactionType.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/CompactionType.java
index c0a5171..1b82951 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/CompactionType.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/CompactionType.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum CompactionType implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum CompactionType implements org.apache.thrift.TEnum {
   MINOR(0),
   MERGE(1),
   MAJOR(2),


[21/25] accumulo git commit: ACCUMULO-3759 More build warnings on Java 8

Posted by ct...@apache.org.
http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/gc/thrift/GCMonitorService.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/gc/thrift/GCMonitorService.java b/core/src/main/java/org/apache/accumulo/core/gc/thrift/GCMonitorService.java
index 9d7ba57..042093a 100644
--- a/core/src/main/java/org/apache/accumulo/core/gc/thrift/GCMonitorService.java
+++ b/core/src/main/java/org/apache/accumulo/core/gc/thrift/GCMonitorService.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class GCMonitorService {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class GCMonitorService {
 
   public interface Iface {
 
@@ -295,7 +295,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.security.thrift.TCredentials credentials; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       CREDENTIALS((short)1, "credentials");
 
@@ -759,7 +759,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/gc/thrift/GCStatus.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/gc/thrift/GCStatus.java b/core/src/main/java/org/apache/accumulo/core/gc/thrift/GCStatus.java
index 7c90b7a..9d6ade6 100644
--- a/core/src/main/java/org/apache/accumulo/core/gc/thrift/GCStatus.java
+++ b/core/src/main/java/org/apache/accumulo/core/gc/thrift/GCStatus.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class GCStatus implements org.apache.thrift.TBase<GCStatus, GCStatus._Fields>, java.io.Serializable, Cloneable, Comparable<GCStatus> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class GCStatus implements org.apache.thrift.TBase<GCStatus, GCStatus._Fields>, java.io.Serializable, Cloneable, Comparable<GCStatus> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("GCStatus");
 
   private static final org.apache.thrift.protocol.TField LAST_FIELD_DESC = new org.apache.thrift.protocol.TField("last", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -68,7 +68,7 @@ import org.slf4j.LoggerFactory;
   public GcCycleStats currentLog; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     LAST((short)1, "last"),
     LAST_LOG((short)2, "lastLog"),
     CURRENT((short)3, "current"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/gc/thrift/GcCycleStats.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/gc/thrift/GcCycleStats.java b/core/src/main/java/org/apache/accumulo/core/gc/thrift/GcCycleStats.java
index a76c14c..83dc826 100644
--- a/core/src/main/java/org/apache/accumulo/core/gc/thrift/GcCycleStats.java
+++ b/core/src/main/java/org/apache/accumulo/core/gc/thrift/GcCycleStats.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class GcCycleStats implements org.apache.thrift.TBase<GcCycleStats, GcCycleStats._Fields>, java.io.Serializable, Cloneable, Comparable<GcCycleStats> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class GcCycleStats implements org.apache.thrift.TBase<GcCycleStats, GcCycleStats._Fields>, java.io.Serializable, Cloneable, Comparable<GcCycleStats> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("GcCycleStats");
 
   private static final org.apache.thrift.protocol.TField STARTED_FIELD_DESC = new org.apache.thrift.protocol.TField("started", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -72,7 +72,7 @@ import org.slf4j.LoggerFactory;
   public long errors; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     STARTED((short)1, "started"),
     FINISHED((short)2, "finished"),
     CANDIDATES((short)3, "candidates"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/Compacting.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/Compacting.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/Compacting.java
index d99d41f..5b1b9cc 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/Compacting.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/Compacting.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class Compacting implements org.apache.thrift.TBase<Compacting, Compacting._Fields>, java.io.Serializable, Cloneable, Comparable<Compacting> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class Compacting implements org.apache.thrift.TBase<Compacting, Compacting._Fields>, java.io.Serializable, Cloneable, Comparable<Compacting> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("Compacting");
 
   private static final org.apache.thrift.protocol.TField RUNNING_FIELD_DESC = new org.apache.thrift.protocol.TField("running", org.apache.thrift.protocol.TType.I32, (short)1);
@@ -64,7 +64,7 @@ import org.slf4j.LoggerFactory;
   public int queued; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     RUNNING((short)1, "running"),
     QUEUED((short)2, "queued");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/DeadServer.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/DeadServer.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/DeadServer.java
index e428589..1cbe5f7 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/DeadServer.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/DeadServer.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class DeadServer implements org.apache.thrift.TBase<DeadServer, DeadServer._Fields>, java.io.Serializable, Cloneable, Comparable<DeadServer> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class DeadServer implements org.apache.thrift.TBase<DeadServer, DeadServer._Fields>, java.io.Serializable, Cloneable, Comparable<DeadServer> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("DeadServer");
 
   private static final org.apache.thrift.protocol.TField SERVER_FIELD_DESC = new org.apache.thrift.protocol.TField("server", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -66,7 +66,7 @@ import org.slf4j.LoggerFactory;
   public String status; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     SERVER((short)1, "server"),
     LAST_STATUS((short)2, "lastStatus"),
     STATUS((short)3, "status");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/FateOperation.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/FateOperation.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/FateOperation.java
index f65f552..c726469 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/FateOperation.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/FateOperation.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum FateOperation implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum FateOperation implements org.apache.thrift.TEnum {
   TABLE_CREATE(0),
   TABLE_CLONE(1),
   TABLE_DELETE(2),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/FateService.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/FateService.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/FateService.java
index 6b337b4..4322808 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/FateService.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/FateService.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class FateService {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class FateService {
 
   public interface Iface {
 
@@ -784,7 +784,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.security.thrift.TCredentials credentials; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       CREDENTIALS((short)1, "credentials");
 
@@ -1248,7 +1248,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -1718,7 +1718,7 @@ import org.slf4j.LoggerFactory;
     public boolean autoClean; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)7, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       OPID((short)2, "opid"),
@@ -2777,7 +2777,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
 
@@ -3237,7 +3237,7 @@ import org.slf4j.LoggerFactory;
     public long opid; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       OPID((short)2, "opid");
@@ -3799,7 +3799,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
@@ -4357,7 +4357,7 @@ import org.slf4j.LoggerFactory;
     public long opid; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       OPID((short)2, "opid");
@@ -4915,7 +4915,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterClientService.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterClientService.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterClientService.java
index 0800aa9..4f4daea 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterClientService.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterClientService.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class MasterClientService {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class MasterClientService {
 
   public interface Iface extends FateService.Iface {
 
@@ -2270,7 +2270,7 @@ import org.slf4j.LoggerFactory;
     public String tableName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       TABLE_NAME((short)2, "tableName");
@@ -2834,7 +2834,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
@@ -3400,7 +3400,7 @@ import org.slf4j.LoggerFactory;
     public long maxLoops; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)5, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       TABLE_NAME((short)2, "tableName"),
@@ -4368,7 +4368,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
 
@@ -4832,7 +4832,7 @@ import org.slf4j.LoggerFactory;
     public String value; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)5, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       TABLE_NAME((short)2, "tableName"),
@@ -5590,7 +5590,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
 
@@ -6052,7 +6052,7 @@ import org.slf4j.LoggerFactory;
     public String property; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)4, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       TABLE_NAME((short)2, "tableName"),
@@ -6712,7 +6712,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
 
@@ -7176,7 +7176,7 @@ import org.slf4j.LoggerFactory;
     public String value; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)5, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       NS((short)2, "ns"),
@@ -7934,7 +7934,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
 
@@ -8396,7 +8396,7 @@ import org.slf4j.LoggerFactory;
     public String property; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)4, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       NS((short)2, "ns"),
@@ -9056,7 +9056,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
 
@@ -9520,7 +9520,7 @@ import org.slf4j.LoggerFactory;
     public MasterGoalState state; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       /**
@@ -10092,7 +10092,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -10452,7 +10452,7 @@ import org.slf4j.LoggerFactory;
     public boolean stopTabletServers; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       STOP_TABLET_SERVERS((short)2, "stopTabletServers");
@@ -11010,7 +11010,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -11372,7 +11372,7 @@ import org.slf4j.LoggerFactory;
     public boolean force; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       TABLET_SERVER((short)2, "tabletServer"),
@@ -12028,7 +12028,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -12390,7 +12390,7 @@ import org.slf4j.LoggerFactory;
     public String value; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)4, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       PROPERTY((short)2, "property"),
@@ -13048,7 +13048,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -13408,7 +13408,7 @@ import org.slf4j.LoggerFactory;
     public String property; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       PROPERTY((short)2, "property");
@@ -13968,7 +13968,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -14326,7 +14326,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.security.thrift.TCredentials credentials; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       CREDENTIALS((short)1, "credentials");
 
@@ -14790,7 +14790,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -15255,7 +15255,7 @@ import org.slf4j.LoggerFactory;
     public TabletSplit split; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)4, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       SERVER_NAME((short)2, "serverName"),
@@ -15930,7 +15930,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.data.thrift.TKeyExtent tablet; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)5, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       SERVER_NAME((short)2, "serverName"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterGoalState.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterGoalState.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterGoalState.java
index 0cf5f15..f436454 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterGoalState.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterGoalState.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum MasterGoalState implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum MasterGoalState implements org.apache.thrift.TEnum {
   CLEAN_STOP(0),
   SAFE_MODE(1),
   NORMAL(2);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterMonitorInfo.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterMonitorInfo.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterMonitorInfo.java
index bd37d3e..990fc89 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterMonitorInfo.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterMonitorInfo.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class MasterMonitorInfo implements org.apache.thrift.TBase<MasterMonitorInfo, MasterMonitorInfo._Fields>, java.io.Serializable, Cloneable, Comparable<MasterMonitorInfo> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class MasterMonitorInfo implements org.apache.thrift.TBase<MasterMonitorInfo, MasterMonitorInfo._Fields>, java.io.Serializable, Cloneable, Comparable<MasterMonitorInfo> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("MasterMonitorInfo");
 
   private static final org.apache.thrift.protocol.TField TABLE_MAP_FIELD_DESC = new org.apache.thrift.protocol.TField("tableMap", org.apache.thrift.protocol.TType.MAP, (short)1);
@@ -84,7 +84,7 @@ import org.slf4j.LoggerFactory;
   public List<DeadServer> deadTabletServers; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     TABLE_MAP((short)1, "tableMap"),
     T_SERVER_INFO((short)2, "tServerInfo"),
     BAD_TSERVERS((short)3, "badTServers"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterState.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterState.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterState.java
index f479fb5..1d63305 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterState.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterState.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum MasterState implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum MasterState implements org.apache.thrift.TEnum {
   INITIAL(0),
   HAVE_LOCK(1),
   SAFE_MODE(2),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/RecoveryException.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/RecoveryException.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/RecoveryException.java
index afb7422..025cced 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/RecoveryException.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/RecoveryException.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class RecoveryException extends TException implements org.apache.thrift.TBase<RecoveryException, RecoveryException._Fields>, java.io.Serializable, Cloneable, Comparable<RecoveryException> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class RecoveryException extends TException implements org.apache.thrift.TBase<RecoveryException, RecoveryException._Fields>, java.io.Serializable, Cloneable, Comparable<RecoveryException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("RecoveryException");
 
   private static final org.apache.thrift.protocol.TField WHY_FIELD_DESC = new org.apache.thrift.protocol.TField("why", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public String why; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     WHY((short)1, "why");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/RecoveryStatus.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/RecoveryStatus.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/RecoveryStatus.java
index 0d14d31..3ffcb03 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/RecoveryStatus.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/RecoveryStatus.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class RecoveryStatus implements org.apache.thrift.TBase<RecoveryStatus, RecoveryStatus._Fields>, java.io.Serializable, Cloneable, Comparable<RecoveryStatus> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class RecoveryStatus implements org.apache.thrift.TBase<RecoveryStatus, RecoveryStatus._Fields>, java.io.Serializable, Cloneable, Comparable<RecoveryStatus> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("RecoveryStatus");
 
   private static final org.apache.thrift.protocol.TField NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("name", org.apache.thrift.protocol.TType.STRING, (short)2);
@@ -66,7 +66,7 @@ import org.slf4j.LoggerFactory;
   public double progress; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     NAME((short)2, "name"),
     RUNTIME((short)5, "runtime"),
     PROGRESS((short)6, "progress");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/TableInfo.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/TableInfo.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/TableInfo.java
index a40df23..3c919cd 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/TableInfo.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/TableInfo.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TableInfo implements org.apache.thrift.TBase<TableInfo, TableInfo._Fields>, java.io.Serializable, Cloneable, Comparable<TableInfo> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TableInfo implements org.apache.thrift.TBase<TableInfo, TableInfo._Fields>, java.io.Serializable, Cloneable, Comparable<TableInfo> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TableInfo");
 
   private static final org.apache.thrift.protocol.TField RECS_FIELD_DESC = new org.apache.thrift.protocol.TField("recs", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -84,7 +84,7 @@ import org.slf4j.LoggerFactory;
   public double scanRate; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     RECS((short)1, "recs"),
     RECS_IN_MEMORY((short)2, "recsInMemory"),
     TABLETS((short)3, "tablets"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletLoadState.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletLoadState.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletLoadState.java
index f951c72..97338cc 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletLoadState.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletLoadState.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum TabletLoadState implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum TabletLoadState implements org.apache.thrift.TEnum {
   LOADED(0),
   LOAD_FAILURE(1),
   UNLOADED(2),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletServerStatus.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletServerStatus.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletServerStatus.java
index 6348537..1f709fb 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletServerStatus.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletServerStatus.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TabletServerStatus implements org.apache.thrift.TBase<TabletServerStatus, TabletServerStatus._Fields>, java.io.Serializable, Cloneable, Comparable<TabletServerStatus> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TabletServerStatus implements org.apache.thrift.TBase<TabletServerStatus, TabletServerStatus._Fields>, java.io.Serializable, Cloneable, Comparable<TabletServerStatus> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TabletServerStatus");
 
   private static final org.apache.thrift.protocol.TField TABLE_MAP_FIELD_DESC = new org.apache.thrift.protocol.TField("tableMap", org.apache.thrift.protocol.TType.MAP, (short)1);
@@ -82,7 +82,7 @@ import org.slf4j.LoggerFactory;
   public List<RecoveryStatus> logSorts; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     TABLE_MAP((short)1, "tableMap"),
     LAST_CONTACT((short)2, "lastContact"),
     NAME((short)3, "name"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletSplit.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletSplit.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletSplit.java
index 2eb671c..bd529b9 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletSplit.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletSplit.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TabletSplit implements org.apache.thrift.TBase<TabletSplit, TabletSplit._Fields>, java.io.Serializable, Cloneable, Comparable<TabletSplit> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TabletSplit implements org.apache.thrift.TBase<TabletSplit, TabletSplit._Fields>, java.io.Serializable, Cloneable, Comparable<TabletSplit> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TabletSplit");
 
   private static final org.apache.thrift.protocol.TField OLD_TABLET_FIELD_DESC = new org.apache.thrift.protocol.TField("oldTablet", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -64,7 +64,7 @@ import org.slf4j.LoggerFactory;
   public List<org.apache.accumulo.core.data.thrift.TKeyExtent> newTablets; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     OLD_TABLET((short)1, "oldTablet"),
     NEW_TABLETS((short)2, "newTablets");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/security/thrift/TCredentials.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/security/thrift/TCredentials.java b/core/src/main/java/org/apache/accumulo/core/security/thrift/TCredentials.java
index 8d3a3e2..0bbd241 100644
--- a/core/src/main/java/org/apache/accumulo/core/security/thrift/TCredentials.java
+++ b/core/src/main/java/org/apache/accumulo/core/security/thrift/TCredentials.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TCredentials implements org.apache.thrift.TBase<TCredentials, TCredentials._Fields>, java.io.Serializable, Cloneable, Comparable<TCredentials> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TCredentials implements org.apache.thrift.TBase<TCredentials, TCredentials._Fields>, java.io.Serializable, Cloneable, Comparable<TCredentials> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TCredentials");
 
   private static final org.apache.thrift.protocol.TField PRINCIPAL_FIELD_DESC = new org.apache.thrift.protocol.TField("principal", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -68,7 +68,7 @@ import org.slf4j.LoggerFactory;
   public String instanceId; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     PRINCIPAL((short)1, "principal"),
     TOKEN_CLASS_NAME((short)2, "tokenClassName"),
     TOKEN((short)3, "token"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActionStats.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActionStats.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActionStats.java
index 0cb5c08..86a502b 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActionStats.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActionStats.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ActionStats implements org.apache.thrift.TBase<ActionStats, ActionStats._Fields>, java.io.Serializable, Cloneable, Comparable<ActionStats> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ActionStats implements org.apache.thrift.TBase<ActionStats, ActionStats._Fields>, java.io.Serializable, Cloneable, Comparable<ActionStats> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ActionStats");
 
   private static final org.apache.thrift.protocol.TField STATUS_FIELD_DESC = new org.apache.thrift.protocol.TField("status", org.apache.thrift.protocol.TType.I32, (short)1);
@@ -76,7 +76,7 @@ import org.slf4j.LoggerFactory;
   public double queueSumDev; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     STATUS((short)1, "status"),
     ELAPSED((short)2, "elapsed"),
     NUM((short)3, "num"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActiveCompaction.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActiveCompaction.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActiveCompaction.java
index c2eddd1..9c1977d 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActiveCompaction.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActiveCompaction.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ActiveCompaction implements org.apache.thrift.TBase<ActiveCompaction, ActiveCompaction._Fields>, java.io.Serializable, Cloneable, Comparable<ActiveCompaction> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ActiveCompaction implements org.apache.thrift.TBase<ActiveCompaction, ActiveCompaction._Fields>, java.io.Serializable, Cloneable, Comparable<ActiveCompaction> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ActiveCompaction");
 
   private static final org.apache.thrift.protocol.TField EXTENT_FIELD_DESC = new org.apache.thrift.protocol.TField("extent", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -90,7 +90,7 @@ import org.slf4j.LoggerFactory;
   public Map<String,Map<String,String>> ssio; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     EXTENT((short)1, "extent"),
     AGE((short)2, "age"),
     INPUT_FILES((short)3, "inputFiles"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActiveScan.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActiveScan.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActiveScan.java
index 5371fd8..fe389e4 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActiveScan.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActiveScan.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ActiveScan implements org.apache.thrift.TBase<ActiveScan, ActiveScan._Fields>, java.io.Serializable, Cloneable, Comparable<ActiveScan> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ActiveScan implements org.apache.thrift.TBase<ActiveScan, ActiveScan._Fields>, java.io.Serializable, Cloneable, Comparable<ActiveScan> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ActiveScan");
 
   private static final org.apache.thrift.protocol.TField CLIENT_FIELD_DESC = new org.apache.thrift.protocol.TField("client", org.apache.thrift.protocol.TType.STRING, (short)2);
@@ -94,7 +94,7 @@ import org.slf4j.LoggerFactory;
   public long scanId; // optional
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     CLIENT((short)2, "client"),
     USER((short)3, "user"),
     TABLE_ID((short)4, "tableId"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/CompactionReason.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/CompactionReason.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/CompactionReason.java
index 36cce96..591dffd 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/CompactionReason.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/CompactionReason.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum CompactionReason implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum CompactionReason implements org.apache.thrift.TEnum {
   USER(0),
   SYSTEM(1),
   CHOP(2),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/CompactionType.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/CompactionType.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/CompactionType.java
index b4fdf68..f2f2cd6 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/CompactionType.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/CompactionType.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum CompactionType implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum CompactionType implements org.apache.thrift.TEnum {
   MINOR(0),
   MERGE(1),
   MAJOR(2),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ConstraintViolationException.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ConstraintViolationException.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ConstraintViolationException.java
index 9515903..7a94159 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ConstraintViolationException.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ConstraintViolationException.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ConstraintViolationException extends TException implements org.apache.thrift.TBase<ConstraintViolationException, ConstraintViolationException._Fields>, java.io.Serializable, Cloneable, Comparable<ConstraintViolationException> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ConstraintViolationException extends TException implements org.apache.thrift.TBase<ConstraintViolationException, ConstraintViolationException._Fields>, java.io.Serializable, Cloneable, Comparable<ConstraintViolationException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ConstraintViolationException");
 
   private static final org.apache.thrift.protocol.TField VIOLATION_SUMMARIES_FIELD_DESC = new org.apache.thrift.protocol.TField("violationSummaries", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public List<org.apache.accumulo.core.data.thrift.TConstraintViolationSummary> violationSummaries; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     VIOLATION_SUMMARIES((short)1, "violationSummaries");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/IteratorConfig.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/IteratorConfig.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/IteratorConfig.java
index 1a05071..9db0608 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/IteratorConfig.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/IteratorConfig.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class IteratorConfig implements org.apache.thrift.TBase<IteratorConfig, IteratorConfig._Fields>, java.io.Serializable, Cloneable, Comparable<IteratorConfig> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class IteratorConfig implements org.apache.thrift.TBase<IteratorConfig, IteratorConfig._Fields>, java.io.Serializable, Cloneable, Comparable<IteratorConfig> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("IteratorConfig");
 
   private static final org.apache.thrift.protocol.TField ITERATORS_FIELD_DESC = new org.apache.thrift.protocol.TField("iterators", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public List<TIteratorSetting> iterators; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     ITERATORS((short)1, "iterators");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/NoSuchScanIDException.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/NoSuchScanIDException.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/NoSuchScanIDException.java
index 79f664f..c0dc02b 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/NoSuchScanIDException.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/NoSuchScanIDException.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class NoSuchScanIDException extends TException implements org.apache.thrift.TBase<NoSuchScanIDException, NoSuchScanIDException._Fields>, java.io.Serializable, Cloneable, Comparable<NoSuchScanIDException> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class NoSuchScanIDException extends TException implements org.apache.thrift.TBase<NoSuchScanIDException, NoSuchScanIDException._Fields>, java.io.Serializable, Cloneable, Comparable<NoSuchScanIDException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("NoSuchScanIDException");
 
 
@@ -60,7 +60,7 @@ import org.slf4j.LoggerFactory;
 
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
 ;
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/NotServingTabletException.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/NotServingTabletException.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/NotServingTabletException.java
index c43b5c0..ef87937 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/NotServingTabletException.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/NotServingTabletException.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class NotServingTabletException extends TException implements org.apache.thrift.TBase<NotServingTabletException, NotServingTabletException._Fields>, java.io.Serializable, Cloneable, Comparable<NotServingTabletException> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class NotServingTabletException extends TException implements org.apache.thrift.TBase<NotServingTabletException, NotServingTabletException._Fields>, java.io.Serializable, Cloneable, Comparable<NotServingTabletException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("NotServingTabletException");
 
   private static final org.apache.thrift.protocol.TField EXTENT_FIELD_DESC = new org.apache.thrift.protocol.TField("extent", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public org.apache.accumulo.core.data.thrift.TKeyExtent extent; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     EXTENT((short)1, "extent");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ScanState.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ScanState.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ScanState.java
index c676599..5bb6857 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ScanState.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ScanState.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum ScanState implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum ScanState implements org.apache.thrift.TEnum {
   IDLE(0),
   RUNNING(1),
   QUEUED(2);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ScanType.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ScanType.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ScanType.java
index cb333a5..34d7ac5 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ScanType.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ScanType.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum ScanType implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum ScanType implements org.apache.thrift.TEnum {
   SINGLE(0),
   BATCH(1);
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TIteratorSetting.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TIteratorSetting.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TIteratorSetting.java
index f457311..8eddaba 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TIteratorSetting.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TIteratorSetting.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TIteratorSetting implements org.apache.thrift.TBase<TIteratorSetting, TIteratorSetting._Fields>, java.io.Serializable, Cloneable, Comparable<TIteratorSetting> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TIteratorSetting implements org.apache.thrift.TBase<TIteratorSetting, TIteratorSetting._Fields>, java.io.Serializable, Cloneable, Comparable<TIteratorSetting> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TIteratorSetting");
 
   private static final org.apache.thrift.protocol.TField PRIORITY_FIELD_DESC = new org.apache.thrift.protocol.TField("priority", org.apache.thrift.protocol.TType.I32, (short)1);
@@ -68,7 +68,7 @@ import org.slf4j.LoggerFactory;
   public Map<String,String> properties; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     PRIORITY((short)1, "priority"),
     NAME((short)2, "name"),
     ITERATOR_CLASS((short)3, "iteratorClass"),


[14/25] accumulo git commit: ACCUMULO-3759 More build warnings on Java 8

Posted by ct...@apache.org.
http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloProxy.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloProxy.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloProxy.java
index 3b23175..b22da8f 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloProxy.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloProxy.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class AccumuloProxy {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class AccumuloProxy {
 
   public interface Iface {
 
@@ -12719,7 +12719,7 @@ import org.slf4j.LoggerFactory;
     public Map<String,String> loginProperties; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       PRINCIPAL((short)1, "principal"),
       LOGIN_PROPERTIES((short)2, "loginProperties");
 
@@ -13225,7 +13225,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH2((short)1, "ouch2");
 
@@ -13694,7 +13694,7 @@ import org.slf4j.LoggerFactory;
     public String constraintClassName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       CONSTRAINT_CLASS_NAME((short)3, "constraintClassName");
@@ -14261,7 +14261,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -14919,7 +14919,7 @@ import org.slf4j.LoggerFactory;
     public Set<ByteBuffer> splits; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       SPLITS((short)3, "splits");
@@ -15533,7 +15533,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -16095,7 +16095,7 @@ import org.slf4j.LoggerFactory;
     public Set<IteratorScope> scopes; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       SETTING((short)3, "setting"),
@@ -16815,7 +16815,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -17377,7 +17377,7 @@ import org.slf4j.LoggerFactory;
     public Set<IteratorScope> scopes; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       SETTING((short)3, "setting"),
@@ -18097,7 +18097,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -18655,7 +18655,7 @@ import org.slf4j.LoggerFactory;
     public String tableName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName");
 
@@ -19118,7 +19118,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch1; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -19484,7 +19484,7 @@ import org.slf4j.LoggerFactory;
     public Set<String> propertiesToExclude; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       NEW_TABLE_NAME((short)3, "newTableName"),
@@ -20444,7 +20444,7 @@ import org.slf4j.LoggerFactory;
     public TableExistsException ouch4; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3"),
@@ -21112,7 +21112,7 @@ import org.slf4j.LoggerFactory;
     public boolean wait; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       START_ROW((short)3, "startRow"),
@@ -22137,7 +22137,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -22695,7 +22695,7 @@ import org.slf4j.LoggerFactory;
     public String tableName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName");
 
@@ -23162,7 +23162,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -23728,7 +23728,7 @@ import org.slf4j.LoggerFactory;
     public TimeType type; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       VERSIONING_ITER((short)3, "versioningIter"),
@@ -24401,7 +24401,7 @@ import org.slf4j.LoggerFactory;
     public TableExistsException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -24959,7 +24959,7 @@ import org.slf4j.LoggerFactory;
     public String tableName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName");
 
@@ -25426,7 +25426,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -25988,7 +25988,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer endRow; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       START_ROW((short)3, "startRow"),
@@ -26673,7 +26673,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -27233,7 +27233,7 @@ import org.slf4j.LoggerFactory;
     public String exportDir; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       EXPORT_DIR((short)3, "exportDir");
@@ -27798,7 +27798,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -28362,7 +28362,7 @@ import org.slf4j.LoggerFactory;
     public boolean wait; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       START_ROW((short)3, "startRow"),
@@ -29143,7 +29143,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -29701,7 +29701,7 @@ import org.slf4j.LoggerFactory;
     public Set<String> tables; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLES((short)2, "tables");
 
@@ -30219,7 +30219,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -30929,7 +30929,7 @@ import org.slf4j.LoggerFactory;
     public String tableName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName");
 
@@ -31398,7 +31398,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -32158,7 +32158,7 @@ import org.slf4j.LoggerFactory;
     public IteratorScope scope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       ITERATOR_NAME((short)3, "iteratorName"),
@@ -32835,7 +32835,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -33506,7 +33506,7 @@ import org.slf4j.LoggerFactory;
     public boolean endInclusive; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       AUTHS((short)3, "auths"),
@@ -34528,7 +34528,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -35195,7 +35195,7 @@ import org.slf4j.LoggerFactory;
     public String tableName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName");
 
@@ -35664,7 +35664,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -36378,7 +36378,7 @@ import org.slf4j.LoggerFactory;
     public boolean setTime; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       IMPORT_DIR((short)3, "importDir"),
@@ -37137,7 +37137,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch4; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH3((short)2, "ouch3"),
       OUCH4((short)3, "ouch4");
@@ -37697,7 +37697,7 @@ import org.slf4j.LoggerFactory;
     public String importDir; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       IMPORT_DIR((short)3, "importDir");
@@ -38262,7 +38262,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -38822,7 +38822,7 @@ import org.slf4j.LoggerFactory;
     public int maxSplits; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       MAX_SPLITS((short)3, "maxSplits");
@@ -39387,7 +39387,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -40090,7 +40090,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer login; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -40455,7 +40455,7 @@ import org.slf4j.LoggerFactory;
     public Set<String> success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -40860,7 +40860,7 @@ import org.slf4j.LoggerFactory;
     public String tableName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName");
 
@@ -41329,7 +41329,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -42084,7 +42084,7 @@ import org.slf4j.LoggerFactory;
     public String tableName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName");
 
@@ -42553,7 +42553,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -43265,7 +43265,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer endRow; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       START_ROW((short)3, "startRow"),
@@ -43950,7 +43950,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -44510,7 +44510,7 @@ import org.slf4j.LoggerFactory;
     public boolean wait; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       WAIT((short)3, "wait");
@@ -45075,7 +45075,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -45635,7 +45635,7 @@ import org.slf4j.LoggerFactory;
     public boolean wait; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       WAIT((short)3, "wait");
@@ -46200,7 +46200,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -46760,7 +46760,7 @@ import org.slf4j.LoggerFactory;
     public int constraint; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       CONSTRAINT((short)3, "constraint");
@@ -47323,7 +47323,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -47885,7 +47885,7 @@ import org.slf4j.LoggerFactory;
     public Set<IteratorScope> scopes; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       ITER_NAME((short)3, "iterName"),
@@ -48600,7 +48600,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -49160,7 +49160,7 @@ import org.slf4j.LoggerFactory;
     public String property; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       PROPERTY((short)3, "property");
@@ -49725,7 +49725,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -50285,7 +50285,7 @@ import org.slf4j.LoggerFactory;
     public String newTableName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       OLD_TABLE_NAME((short)2, "oldTableName"),
       NEW_TABLE_NAME((short)3, "newTableName");
@@ -50852,7 +50852,7 @@ import org.slf4j.LoggerFactory;
     public TableExistsException ouch4; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3"),
@@ -51512,7 +51512,7 @@ import org.slf4j.LoggerFactory;
     public Map<String,Set<String>> groups; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       GROUPS((short)3, "groups");
@@ -52173,7 +52173,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -52735,7 +52735,7 @@ import org.slf4j.LoggerFactory;
     public String value; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       PROPERTY((short)3, "property"),
@@ -53398,7 +53398,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -53960,7 +53960,7 @@ import org.slf4j.LoggerFactory;
     public int maxSplits; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       RANGE((short)3, "range"),
@@ -54628,7 +54628,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -55338,7 +55338,7 @@ import org.slf4j.LoggerFactory;
     public String tableName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName");
 
@@ -55801,7 +55801,7 @@ import org.slf4j.LoggerFactory;
     public boolean success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -56155,7 +56155,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer login; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -56520,7 +56520,7 @@ import org.slf4j.LoggerFactory;
     public Map<String,String> success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -56932,7 +56932,7 @@ import org.slf4j.LoggerFactory;
     public String asTypeName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       CLASS_NAME((short)3, "className"),
@@ -57597,7 +57597,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -58253,7 +58253,7 @@ import org.slf4j.LoggerFactory;
     public String tserver; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TSERVER((short)2, "tserver");
 
@@ -58718,7 +58718,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
 
@@ -59176,7 +59176,7 @@ import org.slf4j.LoggerFactory;
     public String tserver; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TSERVER((short)2, "tserver");
 
@@ -59643,7 +59643,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
@@ -60253,7 +60253,7 @@ import org.slf4j.LoggerFactory;
     public String tserver; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TSERVER((short)2, "tserver");
 
@@ -60720,7 +60720,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
@@ -61328,7 +61328,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer login; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -61697,7 +61697,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
@@ -62303,7 +62303,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer login; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -62672,7 +62672,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
@@ -63278,7 +63278,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer login; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -63643,7 +63643,7 @@ import org.slf4j.LoggerFactory;
     public List<String> success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -64048,7 +64048,7 @@ import org.slf4j.LoggerFactory;
     public String property; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       PROPERTY((short)2, "property");
 
@@ -64513,7 +64513,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
 
@@ -64973,7 +64973,7 @@ import org.slf4j.LoggerFactory;
     public String value; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       PROPERTY((short)2, "property"),
       VALUE((short)3, "value");
@@ -65536,7 +65536,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
 
@@ -65996,7 +65996,7 @@ import org.slf4j.LoggerFactory;
     public String asTypeName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       CLASS_NAME((short)2, "className"),
       AS_TYPE_NAME((short)3, "asTypeName");
@@ -66561,7 +66561,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
@@ -67119,7 +67119,7 @@ import org.slf4j.LoggerFactory;
     public Map<String,String> properties; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       USER((short)2, "user"),
       PROPERTIES((short)3, "properties");
@@ -67736,7 +67736,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
@@ -68294,7 +68294,7 @@ import org.slf4j.LoggerFactory;
     public Set<ByteBuffer> authorizations; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       USER((short)2, "user"),
       AUTHORIZATIONS((short)3, "authorizations");
@@ -68906,7 +68906,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
 
@@ -69366,7 +69366,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer password; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       USER((short)2, "user"),
       PASSWORD((short)3, "password");
@@ -69940,7 +69940,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
 
@@ -70400,7 +70400,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer password; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       USER((short)2, "user"),
       PASSWORD((short)3, "password");
@@ -70974,7 +70974,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
 
@@ -71432,7 +71432,7 @@ import org.slf4j.LoggerFactory;
     public String user; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       USER((short)2, "user");
 
@@ -71897,7 +71897,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
 
@@ -72355,7 +72355,7 @@ import org.slf4j.LoggerFactory;
     public String user; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       USER((short)2, "user");
 
@@ -72822,7 +72822,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
@@ -73433,7 +73433,7 @@ import org.slf4j.LoggerFactory;
     public SystemPermission perm; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       USER((short)2, "user"),
       /**
@@ -74008,7 +74008,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
 
@@ -74474,7 +74474,7 @@ import org.slf4j.LoggerFactory;
     public TablePermission perm; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       USER((short)2, "user"),
       TABLE((short)3, "table"),
@@ -75149,7 +75149,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -75713,7 +75713,7 @@ import org.slf4j.LoggerFactory;
     public SystemPermission perm; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       USER((short)2, "user"),
       /**
@@ -76290,7 +76290,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
@@ -76854,7 +76854,7 @@ import org.slf4j.LoggerFactory;
     public TablePermission perm; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       USER((short)2, "user"),
       TABLE((short)3, "table"),
@@ -77531,7 +77531,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -78185,7 +78185,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer login; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -78556,7 +78556,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -79267,7 +79267,7 @@ import org.slf4j.LoggerFactory;
     public SystemPermission perm; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       USER((short)2, "user"),
       /**
@@ -79842,7 +79842,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
 
@@ -80308,7 +80308,7 @@ import org.slf4j.LoggerFactory;
     public TablePermission perm; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       USER((short)2, "user"),
       TABLE((short)3, "table"),
@@ -80983,7 +80983,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3");
@@ -81543,7 +81543,7 @@ import org.slf4j.LoggerFactory;
     public BatchScanOptions options; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       OPTIONS((short)3, "options");
@@ -82115,7 +82115,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -82773,7 +82773,7 @@ import org.slf4j.LoggerFactory;
     public ScanOptions options; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       OPTIONS((short)3, "options");
@@ -83345,7 +83345,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -83999,7 +83999,7 @@ import org.slf4j.LoggerFactory;
     public String scanner; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SCANNER((short)1, "scanner");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -84355,7 +84355,7 @@ import org.slf4j.LoggerFactory;
     public UnknownScanner ouch1; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1");
 
@@ -84809,7 +84809,7 @@ import org.slf4j.LoggerFactory;
     public String scanner; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SCANNER((short)1, "scanner");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -85169,7 +85169,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -85830,7 +85830,7 @@ import org.slf4j.LoggerFactory;
     public int k; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SCANNER((short)1, "scanner"),
       K((short)2, "k");
 
@@ -86286,7 +86286,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -86945,7 +86945,7 @@ import org.slf4j.LoggerFactory;
     public String scanner; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SCANNER((short)1, "scanner");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -87299,7 +87299,7 @@ import org.slf4j.LoggerFactory;
     public UnknownScanner ouch1; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -87659,7 +87659,7 @@ import org.slf4j.LoggerFactory;
     public Map<ByteBuffer,List<ColumnUpdate>> cells; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       CELLS((short)3, "cells");
@@ -88328,7 +88328,7 @@ import org.slf4j.LoggerFactory;
     public MutationsRejectedException ouch4; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUTCH1((short)1, "outch1"),
       OUCH2((short)2, "ouch2"),
       OUCH3((short)3, "ouch3"),
@@ -88988,7 +88988,7 @@ import org.slf4j.LoggerFactory;
     public WriterOptions opts; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       OPTS((short)3, "opts");
@@ -89560,7 +89560,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUTCH1((short)1, "outch1"),
       OUCH2((short)2, "ouch2"),
@@ -90216,7 +90216,7 @@ import org.slf4j.LoggerFactory;
     public Map<ByteBuffer,List<ColumnUpdate>> cells; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       WRITER((short)1, "writer"),
       CELLS((short)2, "cells");
 
@@ -90770,7 +90770,7 @@ import org.slf4j.LoggerFactory;
     public String writer; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       WRITER((short)1, "writer");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -91126,7 +91126,7 @@ import org.slf4j.LoggerFactory;
     public MutationsRejectedException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
 
@@ -91582,7 +91582,7 @@ import org.slf4j.LoggerFactory;
     public String writer; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       WRITER((short)1, "writer");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -91938,7 +91938,7 @@ import org.slf4j.LoggerFactory;
     public MutationsRejectedException ouch2; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2");
 
@@ -92400,7 +92400,7 @@ import org.slf4j.LoggerFactory;
     public ConditionalUpdates updates; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       ROW((short)3, "row"),
@@ -93085,7 +93085,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       /**
        * 
        * @see ConditionalStatus
@@ -93755,7 +93755,7 @@ import org.slf4j.LoggerFactory;
     public ConditionalWriterOptions options; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       LOGIN((short)1, "login"),
       TABLE_NAME((short)2, "tableName"),
       OPTIONS((short)3, "options");
@@ -94327,7 +94327,7 @@ import org.slf4j.LoggerFactory;
     public TableNotFoundException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -94983,7 +94983,7 @@ import org.slf4j.LoggerFactory;
     public Map<ByteBuffer,ConditionalUpdates> updates; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       CONDITIONAL_WRITER((short)1, "conditionalWriter"),
       UPDATES((short)2, "updates");
 
@@ -95507,7 +95507,7 @@ import org.slf4j.LoggerFactory;
     public AccumuloSecurityException ouch3; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       OUCH1((short)1, "ouch1"),
       OUCH2((short)2, "ouch2"),
@@ -96225,7 +96225,7 @@ import org.slf4j.LoggerFactory;
     public String conditionalWriter; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       CONDITIONAL_WRITER((short)1, "conditionalWriter");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -96577,7 +96577,7 @@ import org.slf4j.LoggerFactory;
 
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
 ;
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -96825,7 +96825,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer row; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       ROW((short)1, "row");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -97190,7 +97190,7 @@ import org.slf4j.LoggerFactory;
     public Range success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -97555,7 +97555,7 @@ import org.slf4j.LoggerFactory;
     public PartialKey part; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       KEY((short)1, "key"),
       /**
        * 
@@ -98024,7 +98024,7 @@ import org.slf4j.LoggerFactory;
     public Key success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloSecurityException.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloSecurityException.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloSecurityException.java
index 55e074b..28b1e6c 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloSecurityException.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloSecurityException.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class AccumuloSecurityException extends TException implements org.apache.thrift.TBase<AccumuloSecurityException, AccumuloSecurityException._Fields>, java.io.Serializable, Cloneable, Comparable<AccumuloSecurityException> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class AccumuloSecurityException extends TException implements org.apache.thrift.TBase<AccumuloSecurityException, AccumuloSecurityException._Fields>, java.io.Serializable, Cloneable, Comparable<AccumuloSecurityException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("AccumuloSecurityException");
 
   private static final org.apache.thrift.protocol.TField MSG_FIELD_DESC = new org.apache.thrift.protocol.TField("msg", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public String msg; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     MSG((short)1, "msg");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ActiveCompaction.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ActiveCompaction.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ActiveCompaction.java
index 05de413..58e1321 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ActiveCompaction.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ActiveCompaction.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ActiveCompaction implements org.apache.thrift.TBase<ActiveCompaction, ActiveCompaction._Fields>, java.io.Serializable, Cloneable, Comparable<ActiveCompaction> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ActiveCompaction implements org.apache.thrift.TBase<ActiveCompaction, ActiveCompaction._Fields>, java.io.Serializable, Cloneable, Comparable<ActiveCompaction> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ActiveCompaction");
 
   private static final org.apache.thrift.protocol.TField EXTENT_FIELD_DESC = new org.apache.thrift.protocol.TField("extent", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -88,7 +88,7 @@ import org.slf4j.LoggerFactory;
   public List<IteratorSetting> iterators; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     EXTENT((short)1, "extent"),
     AGE((short)2, "age"),
     INPUT_FILES((short)3, "inputFiles"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ActiveScan.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ActiveScan.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ActiveScan.java
index a34e57f..bc9ad51 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ActiveScan.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ActiveScan.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ActiveScan implements org.apache.thrift.TBase<ActiveScan, ActiveScan._Fields>, java.io.Serializable, Cloneable, Comparable<ActiveScan> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ActiveScan implements org.apache.thrift.TBase<ActiveScan, ActiveScan._Fields>, java.io.Serializable, Cloneable, Comparable<ActiveScan> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ActiveScan");
 
   private static final org.apache.thrift.protocol.TField CLIENT_FIELD_DESC = new org.apache.thrift.protocol.TField("client", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -90,7 +90,7 @@ import org.slf4j.LoggerFactory;
   public List<ByteBuffer> authorizations; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     CLIENT((short)1, "client"),
     USER((short)2, "user"),
     TABLE((short)3, "table"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/BatchScanOptions.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/BatchScanOptions.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/BatchScanOptions.java
index e749ac4..948d822 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/BatchScanOptions.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/BatchScanOptions.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class BatchScanOptions implements org.apache.thrift.TBase<BatchScanOptions, BatchScanOptions._Fields>, java.io.Serializable, Cloneable, Comparable<BatchScanOptions> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class BatchScanOptions implements org.apache.thrift.TBase<BatchScanOptions, BatchScanOptions._Fields>, java.io.Serializable, Cloneable, Comparable<BatchScanOptions> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("BatchScanOptions");
 
   private static final org.apache.thrift.protocol.TField AUTHORIZATIONS_FIELD_DESC = new org.apache.thrift.protocol.TField("authorizations", org.apache.thrift.protocol.TType.SET, (short)1);
@@ -70,7 +70,7 @@ import org.slf4j.LoggerFactory;
   public int threads; // optional
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     AUTHORIZATIONS((short)1, "authorizations"),
     RANGES((short)2, "ranges"),
     COLUMNS((short)3, "columns"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Column.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Column.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Column.java
index 3c20017..007eb53 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Column.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/Column.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class Column implements org.apache.thrift.TBase<Column, Column._Fields>, java.io.Serializable, Cloneable, Comparable<Column> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class Column implements org.apache.thrift.TBase<Column, Column._Fields>, java.io.Serializable, Cloneable, Comparable<Column> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("Column");
 
   private static final org.apache.thrift.protocol.TField COL_FAMILY_FIELD_DESC = new org.apache.thrift.protocol.TField("colFamily", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -66,7 +66,7 @@ import org.slf4j.LoggerFactory;
   public ByteBuffer colVisibility; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     COL_FAMILY((short)1, "colFamily"),
     COL_QUALIFIER((short)2, "colQualifier"),
     COL_VISIBILITY((short)3, "colVisibility");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ColumnUpdate.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ColumnUpdate.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ColumnUpdate.java
index a3b040e..97d9542 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ColumnUpdate.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/ColumnUpdate.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ColumnUpdate implements org.apache.thrift.TBase<ColumnUpdate, ColumnUpdate._Fields>, java.io.Serializable, Cloneable, Comparable<ColumnUpdate> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ColumnUpdate implements org.apache.thrift.TBase<ColumnUpdate, ColumnUpdate._Fields>, java.io.Serializable, Cloneable, Comparable<ColumnUpdate> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ColumnUpdate");
 
   private static final org.apache.thrift.protocol.TField COL_FAMILY_FIELD_DESC = new org.apache.thrift.protocol.TField("colFamily", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -72,7 +72,7 @@ import org.slf4j.LoggerFactory;
   public boolean deleteCell; // optional
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     COL_FAMILY((short)1, "colFamily"),
     COL_QUALIFIER((short)2, "colQualifier"),
     COL_VISIBILITY((short)3, "colVisibility"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/CompactionReason.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/CompactionReason.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/CompactionReason.java
index 36bc32a..1875275 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/CompactionReason.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/CompactionReason.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum CompactionReason implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum CompactionReason implements org.apache.thrift.TEnum {
   USER(0),
   SYSTEM(1),
   CHOP(2),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/CompactionType.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/CompactionType.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/CompactionType.java
index c0a5171..1b82951 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/CompactionType.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/CompactionType.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum CompactionType implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum CompactionType implements org.apache.thrift.TEnum {
   MINOR(0),
   MERGE(1),
   MAJOR(2),


[10/25] accumulo git commit: ACCUMULO-3759 More build warnings on Java 8

Posted by ct...@apache.org.
http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TabletClientService.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TabletClientService.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TabletClientService.java
index 2ba7674..3384e00 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TabletClientService.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TabletClientService.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TabletClientService {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TabletClientService {
 
   public interface Iface extends org.apache.accumulo.core.client.impl.thrift.ClientService.Iface {
 
@@ -4336,7 +4336,7 @@ import org.slf4j.LoggerFactory;
     public long readaheadThreshold; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)11, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       EXTENT((short)2, "extent"),
@@ -6034,7 +6034,7 @@ import org.slf4j.LoggerFactory;
     public TooManyFilesException tmfe; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec"),
       NSTE((short)2, "nste"),
@@ -6695,7 +6695,7 @@ import org.slf4j.LoggerFactory;
     public long scanID; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       SCAN_ID((short)1, "scanID");
 
@@ -7156,7 +7156,7 @@ import org.slf4j.LoggerFactory;
     public TooManyFilesException tmfe; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       NSSI((short)1, "nssi"),
       NSTE((short)2, "nste"),
@@ -7817,7 +7817,7 @@ import org.slf4j.LoggerFactory;
     public long scanID; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       SCAN_ID((short)1, "scanID");
 
@@ -8286,7 +8286,7 @@ import org.slf4j.LoggerFactory;
     public boolean waitForWrites; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)8, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       BATCH((short)2, "batch"),
@@ -9681,7 +9681,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -10142,7 +10142,7 @@ import org.slf4j.LoggerFactory;
     public long scanID; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       SCAN_ID((short)1, "scanID");
 
@@ -10599,7 +10599,7 @@ import org.slf4j.LoggerFactory;
     public NoSuchScanIDException nssi; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       NSSI((short)1, "nssi");
 
@@ -11060,7 +11060,7 @@ import org.slf4j.LoggerFactory;
     public long scanID; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       SCAN_ID((short)1, "scanID");
 
@@ -11515,7 +11515,7 @@ import org.slf4j.LoggerFactory;
     public NoSuchScanIDException nssi; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       NSSI((short)1, "nssi");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -11873,7 +11873,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.security.thrift.TCredentials credentials; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       CREDENTIALS((short)1, "credentials");
 
@@ -12337,7 +12337,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -12797,7 +12797,7 @@ import org.slf4j.LoggerFactory;
     public List<org.apache.accumulo.core.data.thrift.TMutation> mutations; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       UPDATE_ID((short)2, "updateID"),
       KEY_EXTENT((short)3, "keyExtent"),
@@ -13509,7 +13509,7 @@ import org.slf4j.LoggerFactory;
     public long updateID; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       UPDATE_ID((short)1, "updateID");
 
@@ -13966,7 +13966,7 @@ import org.slf4j.LoggerFactory;
     public NoSuchScanIDException nssi; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       NSSI((short)1, "nssi");
 
@@ -14431,7 +14431,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.data.thrift.TMutation mutation; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)4, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       KEY_EXTENT((short)2, "keyExtent"),
@@ -15103,7 +15103,7 @@ import org.slf4j.LoggerFactory;
     public ConstraintViolationException cve; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec"),
       NSTE((short)2, "nste"),
       CVE((short)3, "cve");
@@ -15665,7 +15665,7 @@ import org.slf4j.LoggerFactory;
     public String tableID; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)2, "credentials"),
       AUTHORIZATIONS((short)3, "authorizations"),
@@ -16374,7 +16374,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -16839,7 +16839,7 @@ import org.slf4j.LoggerFactory;
     public List<String> symbols; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       SESS_ID((short)2, "sessID"),
       MUTATIONS((short)3, "mutations"),
@@ -17626,7 +17626,7 @@ import org.slf4j.LoggerFactory;
     public NoSuchScanIDException nssi; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       NSSI((short)1, "nssi");
 
@@ -18136,7 +18136,7 @@ import org.slf4j.LoggerFactory;
     public long sessID; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       SESS_ID((short)2, "sessID");
 
@@ -18589,7 +18589,7 @@ import org.slf4j.LoggerFactory;
 
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
 ;
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -18839,7 +18839,7 @@ import org.slf4j.LoggerFactory;
     public long sessID; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       SESS_ID((short)2, "sessID");
 
@@ -19302,7 +19302,7 @@ import org.slf4j.LoggerFactory;
     public boolean setTime; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       TID((short)4, "tid"),
@@ -20143,7 +20143,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -20657,7 +20657,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer splitPoint; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)4, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       EXTENT((short)2, "extent"),
@@ -21333,7 +21333,7 @@ import org.slf4j.LoggerFactory;
     public NotServingTabletException nste; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec"),
       NSTE((short)2, "nste");
 
@@ -21795,7 +21795,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.data.thrift.TKeyExtent extent; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)5, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       LOCK((short)4, "lock"),
@@ -22466,7 +22466,7 @@ import org.slf4j.LoggerFactory;
     public boolean save; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)5, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       LOCK((short)4, "lock"),
@@ -23235,7 +23235,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer endRow; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)4, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       LOCK((short)3, "lock"),
@@ -24117,7 +24117,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.data.thrift.TKeyExtent extent; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)2, "credentials"),
       LOCK((short)3, "lock"),
@@ -24786,7 +24786,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.data.thrift.TKeyExtent extent; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)2, "credentials"),
       LOCK((short)3, "lock"),
@@ -25459,7 +25459,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer endRow; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)2, "credentials"),
       LOCK((short)3, "lock"),
@@ -26337,7 +26337,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.security.thrift.TCredentials credentials; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)1, "credentials");
 
@@ -26801,7 +26801,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -27264,7 +27264,7 @@ import org.slf4j.LoggerFactory;
     public String tableId; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       TABLE_ID((short)2, "tableId");
@@ -27826,7 +27826,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -28336,7 +28336,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.security.thrift.TCredentials credentials; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       CREDENTIALS((short)1, "credentials");
 
@@ -28800,7 +28800,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -29263,7 +29263,7 @@ import org.slf4j.LoggerFactory;
     public String lock; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       LOCK((short)2, "lock");
@@ -29823,7 +29823,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -30183,7 +30183,7 @@ import org.slf4j.LoggerFactory;
     public String lock; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       LOCK((short)2, "lock");
@@ -30745,7 +30745,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.security.thrift.TCredentials credentials; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       CREDENTIALS((short)1, "credentials");
 
@@ -31209,7 +31209,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -31719,7 +31719,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.security.thrift.TCredentials credentials; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       CREDENTIALS((short)1, "credentials");
 
@@ -32183,7 +32183,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -32695,7 +32695,7 @@ import org.slf4j.LoggerFactory;
     public List<String> filenames; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)2, "credentials"),
       FILENAMES((short)3, "filenames");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TabletStats.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TabletStats.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TabletStats.java
index 8989fe5..310d3b6 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TabletStats.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TabletStats.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TabletStats implements org.apache.thrift.TBase<TabletStats, TabletStats._Fields>, java.io.Serializable, Cloneable, Comparable<TabletStats> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TabletStats implements org.apache.thrift.TBase<TabletStats, TabletStats._Fields>, java.io.Serializable, Cloneable, Comparable<TabletStats> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TabletStats");
 
   private static final org.apache.thrift.protocol.TField EXTENT_FIELD_DESC = new org.apache.thrift.protocol.TField("extent", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -76,7 +76,7 @@ import org.slf4j.LoggerFactory;
   public long splitCreationTime; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     EXTENT((short)1, "extent"),
     MAJORS((short)2, "majors"),
     MINORS((short)3, "minors"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TooManyFilesException.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TooManyFilesException.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TooManyFilesException.java
index cc4c3e8..203597a 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TooManyFilesException.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TooManyFilesException.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TooManyFilesException extends TException implements org.apache.thrift.TBase<TooManyFilesException, TooManyFilesException._Fields>, java.io.Serializable, Cloneable, Comparable<TooManyFilesException> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TooManyFilesException extends TException implements org.apache.thrift.TBase<TooManyFilesException, TooManyFilesException._Fields>, java.io.Serializable, Cloneable, Comparable<TooManyFilesException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TooManyFilesException");
 
   private static final org.apache.thrift.protocol.TField EXTENT_FIELD_DESC = new org.apache.thrift.protocol.TField("extent", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public org.apache.accumulo.core.data.thrift.TKeyExtent extent; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     EXTENT((short)1, "extent");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/scripts/generate-thrift.sh
----------------------------------------------------------------------
diff --git a/core/src/main/scripts/generate-thrift.sh b/core/src/main/scripts/generate-thrift.sh
index ee5bb8e..8c2a623 100755
--- a/core/src/main/scripts/generate-thrift.sh
+++ b/core/src/main/scripts/generate-thrift.sh
@@ -26,23 +26,23 @@
 #   INCLUDED_MODULES should be an array that includes other Maven modules with src/main/thrift directories
 #   Use INCLUDED_MODULES=(-) in calling scripts that require no other modules
 # ========================================================================================================================
-[ -z $REQUIRED_THRIFT_VERSION ] && REQUIRED_THRIFT_VERSION='0.9.1'
-[ -z $INCLUDED_MODULES ]        && INCLUDED_MODULES=(../trace)
-[ -z $BASE_OUTPUT_PACKAGE ]     && BASE_OUTPUT_PACKAGE='org.apache.accumulo.core'
-[ -z $PACKAGES_TO_GENERATE ]    && PACKAGES_TO_GENERATE=(gc master tabletserver security client.impl data)
-[ -z $BUILD_DIR ]               && BUILD_DIR='target'
-[ -z $LANGUAGES_TO_GENERATE ]   && LANGUAGES_TO_GENERATE=(java)
-[ -z $FINAL_DIR ]               && FINAL_DIR='src/main'
+[[ -z $REQUIRED_THRIFT_VERSION ]] && REQUIRED_THRIFT_VERSION='0.9.1'
+[[ -z $INCLUDED_MODULES ]]        && INCLUDED_MODULES=(../trace)
+[[ -z $BASE_OUTPUT_PACKAGE ]]     && BASE_OUTPUT_PACKAGE='org.apache.accumulo.core'
+[[ -z $PACKAGES_TO_GENERATE ]]    && PACKAGES_TO_GENERATE=(gc master tabletserver security client.impl data)
+[[ -z $BUILD_DIR ]]               && BUILD_DIR='target'
+[[ -z $LANGUAGES_TO_GENERATE ]]   && LANGUAGES_TO_GENERATE=(java)
+[[ -z $FINAL_DIR ]]               && FINAL_DIR='src/main'
 # ========================================================================================================================
 
 fail() {
-  echo $@
+  echo "$@"
   exit 1
 }
 
 # Test to see if we have thrift installed
-VERSION=$(thrift -version 2>/dev/null | grep -F "${REQUIRED_THRIFT_VERSION}" |  wc -l)
-if [ "$VERSION" -ne 1 ] ; then 
+VERSION=$(thrift -version 2>/dev/null | grep -F "${REQUIRED_THRIFT_VERSION}" |  wc -l | sed -e 's/^ *//' -e 's/ *$//')
+if [[ "${VERSION}" != '1' ]] ; then
   # Nope: bail
   echo "****************************************************"
   echo "*** thrift is not available"
@@ -65,15 +65,17 @@ THRIFT_ARGS="${THRIFT_ARGS} -o $BUILD_DIR"
 mkdir -p $BUILD_DIR
 rm -rf $BUILD_DIR/gen-java
 for f in src/main/thrift/*.thrift; do
-  thrift ${THRIFT_ARGS} --gen java $f || fail unable to generate java thrift classes
-  thrift ${THRIFT_ARGS} --gen py $f || fail unable to generate python thrift classes
-  thrift ${THRIFT_ARGS} --gen rb $f || fail unable to generate ruby thrift classes
-  thrift ${THRIFT_ARGS} --gen cpp $f || fail unable to generate cpp thrift classes
+  thrift ${THRIFT_ARGS} --gen java "$f" || fail unable to generate java thrift classes
+  thrift ${THRIFT_ARGS} --gen py "$f" || fail unable to generate python thrift classes
+  thrift ${THRIFT_ARGS} --gen rb "$f" || fail unable to generate ruby thrift classes
+  thrift ${THRIFT_ARGS} --gen cpp "$f" || fail unable to generate cpp thrift classes
 done
 
 # For all generated thrift code, suppress all warnings and add the LICENSE header
-find $BUILD_DIR/gen-java -name '*.java' -print0 | xargs -0 sed -i.orig -e 's/public class /@SuppressWarnings("all") public class /'
-find $BUILD_DIR/gen-java -name '*.java' -print0 | xargs -0 sed -i.orig -e 's/public enum /@SuppressWarnings("all") public enum /'
+cs='@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"})'
+es='@SuppressWarnings({"unused"})'
+find $BUILD_DIR/gen-java -name '*.java' -print0 | xargs -0 sed -i.orig -e 's/\(public class [A-Z]\)/'"$cs"' \1/'
+find $BUILD_DIR/gen-java -name '*.java' -print0 | xargs -0 sed -i.orig -e 's/\(public enum [A-Z]\)/'"$es"' \1/'
 
 for lang in "${LANGUAGES_TO_GENERATE[@]}"; do
   case $lang in
@@ -109,10 +111,10 @@ for lang in "${LANGUAGES_TO_GENERATE[@]}"; do
       continue
       ;;
   esac
-  
-  for file in ${FILE_SUFFIX[@]}; do
+
+  for file in "${FILE_SUFFIX[@]}"; do
     for f in $(find $BUILD_DIR/gen-$lang -name "*$file"); do
-      cat - $f >${f}-with-license <<EOF
+      cat - "$f" > "${f}-with-license" <<EOF
 ${PREFIX}${LINE_NOTATION} Licensed to the Apache Software Foundation (ASF) under one or more
 ${LINE_NOTATION} contributor license agreements.  See the NOTICE file distributed with
 ${LINE_NOTATION} this work for additional information regarding copyright ownership.
@@ -135,7 +137,7 @@ done
 # For every generated java file, compare it with the version-controlled one, and copy the ones that have changed into place
 for d in "${PACKAGES_TO_GENERATE[@]}"; do
   for lang in "${LANGUAGES_TO_GENERATE[@]}"; do
-    case $lang in
+    case "$lang" in
       cpp)
         SDIR="${BUILD_DIR}/gen-$lang/"
         DDIR="${FINAL_DIR}/cpp/"
@@ -161,11 +163,11 @@ for d in "${PACKAGES_TO_GENERATE[@]}"; do
         ;;
     esac
     mkdir -p "$DDIR"
-    for file in ${FILE_SUFFIX[@]}; do
-      for f in `find $SDIR -name *$file`; do
-        DEST="$DDIR/`basename $f`"
+    for file in "${FILE_SUFFIX[@]}"; do
+      for f in $(find $SDIR -name *$file); do
+        DEST="$DDIR/$(basename $f)"
         if ! cmp -s "${f}-with-license" "${DEST}" ; then
-          echo cp -f "${f}-with-license" "${DEST}" 
+          echo cp -f "${f}-with-license" "${DEST}"
           cp -f "${f}-with-license" "${DEST}" || fail unable to copy files to java workspace
         fi
       done

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index 3389795..9249a5b 100644
--- a/pom.xml
+++ b/pom.xml
@@ -118,6 +118,8 @@
     <accumulo.release.version>${project.version}</accumulo.release.version>
     <!-- bouncycastle version for test dependencies -->
     <bouncycastle.version>1.50</bouncycastle.version>
+    <!-- findbugs-maven-plugin won't work on jdk8 or later; set to 3.0.0 or newer -->
+    <findbugs.version>2.5.5</findbugs.version>
     <!-- surefire/failsafe plugin option -->
     <forkCount>1</forkCount>
     <!-- overwritten in profiles hadoop-1 or hadoop-2 -->
@@ -499,7 +501,7 @@
         <plugin>
           <groupId>org.codehaus.mojo</groupId>
           <artifactId>findbugs-maven-plugin</artifactId>
-          <version>2.5.5</version>
+          <version>${findbugs.version}</version>
           <configuration>
             <xmlOutput>true</xmlOutput>
             <effort>Max</effort>
@@ -1141,7 +1143,7 @@
       <plugin>
         <groupId>org.codehaus.mojo</groupId>
         <artifactId>findbugs-maven-plugin</artifactId>
-        <version>2.5.3</version>
+        <version>${findbugs.version}</version>
         <configuration>
           <excludeFilterFile>contrib/findbugs-exclude.xml</excludeFilterFile>
           <findbugsXmlOutput>true</findbugsXmlOutput>

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloException.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloException.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloException.java
index 0be034c..724a92e 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloException.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloException.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class AccumuloException extends TException implements org.apache.thrift.TBase<AccumuloException, AccumuloException._Fields>, java.io.Serializable, Cloneable, Comparable<AccumuloException> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class AccumuloException extends TException implements org.apache.thrift.TBase<AccumuloException, AccumuloException._Fields>, java.io.Serializable, Cloneable, Comparable<AccumuloException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("AccumuloException");
 
   private static final org.apache.thrift.protocol.TField MSG_FIELD_DESC = new org.apache.thrift.protocol.TField("msg", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public String msg; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     MSG((short)1, "msg");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();


[11/25] accumulo git commit: ACCUMULO-3759 More build warnings on Java 8

Posted by ct...@apache.org.
http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/gc/thrift/GCMonitorService.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/gc/thrift/GCMonitorService.java b/core/src/main/java/org/apache/accumulo/core/gc/thrift/GCMonitorService.java
index 9d7ba57..042093a 100644
--- a/core/src/main/java/org/apache/accumulo/core/gc/thrift/GCMonitorService.java
+++ b/core/src/main/java/org/apache/accumulo/core/gc/thrift/GCMonitorService.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class GCMonitorService {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class GCMonitorService {
 
   public interface Iface {
 
@@ -295,7 +295,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.security.thrift.TCredentials credentials; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       CREDENTIALS((short)1, "credentials");
 
@@ -759,7 +759,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/gc/thrift/GCStatus.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/gc/thrift/GCStatus.java b/core/src/main/java/org/apache/accumulo/core/gc/thrift/GCStatus.java
index 7c90b7a..9d6ade6 100644
--- a/core/src/main/java/org/apache/accumulo/core/gc/thrift/GCStatus.java
+++ b/core/src/main/java/org/apache/accumulo/core/gc/thrift/GCStatus.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class GCStatus implements org.apache.thrift.TBase<GCStatus, GCStatus._Fields>, java.io.Serializable, Cloneable, Comparable<GCStatus> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class GCStatus implements org.apache.thrift.TBase<GCStatus, GCStatus._Fields>, java.io.Serializable, Cloneable, Comparable<GCStatus> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("GCStatus");
 
   private static final org.apache.thrift.protocol.TField LAST_FIELD_DESC = new org.apache.thrift.protocol.TField("last", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -68,7 +68,7 @@ import org.slf4j.LoggerFactory;
   public GcCycleStats currentLog; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     LAST((short)1, "last"),
     LAST_LOG((short)2, "lastLog"),
     CURRENT((short)3, "current"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/gc/thrift/GcCycleStats.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/gc/thrift/GcCycleStats.java b/core/src/main/java/org/apache/accumulo/core/gc/thrift/GcCycleStats.java
index a76c14c..83dc826 100644
--- a/core/src/main/java/org/apache/accumulo/core/gc/thrift/GcCycleStats.java
+++ b/core/src/main/java/org/apache/accumulo/core/gc/thrift/GcCycleStats.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class GcCycleStats implements org.apache.thrift.TBase<GcCycleStats, GcCycleStats._Fields>, java.io.Serializable, Cloneable, Comparable<GcCycleStats> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class GcCycleStats implements org.apache.thrift.TBase<GcCycleStats, GcCycleStats._Fields>, java.io.Serializable, Cloneable, Comparable<GcCycleStats> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("GcCycleStats");
 
   private static final org.apache.thrift.protocol.TField STARTED_FIELD_DESC = new org.apache.thrift.protocol.TField("started", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -72,7 +72,7 @@ import org.slf4j.LoggerFactory;
   public long errors; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     STARTED((short)1, "started"),
     FINISHED((short)2, "finished"),
     CANDIDATES((short)3, "candidates"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/Compacting.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/Compacting.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/Compacting.java
index d99d41f..5b1b9cc 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/Compacting.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/Compacting.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class Compacting implements org.apache.thrift.TBase<Compacting, Compacting._Fields>, java.io.Serializable, Cloneable, Comparable<Compacting> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class Compacting implements org.apache.thrift.TBase<Compacting, Compacting._Fields>, java.io.Serializable, Cloneable, Comparable<Compacting> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("Compacting");
 
   private static final org.apache.thrift.protocol.TField RUNNING_FIELD_DESC = new org.apache.thrift.protocol.TField("running", org.apache.thrift.protocol.TType.I32, (short)1);
@@ -64,7 +64,7 @@ import org.slf4j.LoggerFactory;
   public int queued; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     RUNNING((short)1, "running"),
     QUEUED((short)2, "queued");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/DeadServer.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/DeadServer.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/DeadServer.java
index e428589..1cbe5f7 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/DeadServer.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/DeadServer.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class DeadServer implements org.apache.thrift.TBase<DeadServer, DeadServer._Fields>, java.io.Serializable, Cloneable, Comparable<DeadServer> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class DeadServer implements org.apache.thrift.TBase<DeadServer, DeadServer._Fields>, java.io.Serializable, Cloneable, Comparable<DeadServer> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("DeadServer");
 
   private static final org.apache.thrift.protocol.TField SERVER_FIELD_DESC = new org.apache.thrift.protocol.TField("server", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -66,7 +66,7 @@ import org.slf4j.LoggerFactory;
   public String status; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     SERVER((short)1, "server"),
     LAST_STATUS((short)2, "lastStatus"),
     STATUS((short)3, "status");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/FateOperation.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/FateOperation.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/FateOperation.java
index f65f552..c726469 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/FateOperation.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/FateOperation.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum FateOperation implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum FateOperation implements org.apache.thrift.TEnum {
   TABLE_CREATE(0),
   TABLE_CLONE(1),
   TABLE_DELETE(2),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/FateService.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/FateService.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/FateService.java
index 6b337b4..4322808 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/FateService.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/FateService.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class FateService {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class FateService {
 
   public interface Iface {
 
@@ -784,7 +784,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.security.thrift.TCredentials credentials; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       CREDENTIALS((short)1, "credentials");
 
@@ -1248,7 +1248,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -1718,7 +1718,7 @@ import org.slf4j.LoggerFactory;
     public boolean autoClean; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)7, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       OPID((short)2, "opid"),
@@ -2777,7 +2777,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
 
@@ -3237,7 +3237,7 @@ import org.slf4j.LoggerFactory;
     public long opid; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       OPID((short)2, "opid");
@@ -3799,7 +3799,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
@@ -4357,7 +4357,7 @@ import org.slf4j.LoggerFactory;
     public long opid; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       OPID((short)2, "opid");
@@ -4915,7 +4915,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterClientService.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterClientService.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterClientService.java
index 0800aa9..4f4daea 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterClientService.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterClientService.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class MasterClientService {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class MasterClientService {
 
   public interface Iface extends FateService.Iface {
 
@@ -2270,7 +2270,7 @@ import org.slf4j.LoggerFactory;
     public String tableName; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       TABLE_NAME((short)2, "tableName");
@@ -2834,7 +2834,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
@@ -3400,7 +3400,7 @@ import org.slf4j.LoggerFactory;
     public long maxLoops; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)5, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       TABLE_NAME((short)2, "tableName"),
@@ -4368,7 +4368,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
 
@@ -4832,7 +4832,7 @@ import org.slf4j.LoggerFactory;
     public String value; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)5, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       TABLE_NAME((short)2, "tableName"),
@@ -5590,7 +5590,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
 
@@ -6052,7 +6052,7 @@ import org.slf4j.LoggerFactory;
     public String property; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)4, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       TABLE_NAME((short)2, "tableName"),
@@ -6712,7 +6712,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
 
@@ -7176,7 +7176,7 @@ import org.slf4j.LoggerFactory;
     public String value; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)5, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       NS((short)2, "ns"),
@@ -7934,7 +7934,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
 
@@ -8396,7 +8396,7 @@ import org.slf4j.LoggerFactory;
     public String property; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)4, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       NS((short)2, "ns"),
@@ -9056,7 +9056,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException tope; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec"),
       TOPE((short)2, "tope");
 
@@ -9520,7 +9520,7 @@ import org.slf4j.LoggerFactory;
     public MasterGoalState state; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       /**
@@ -10092,7 +10092,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -10452,7 +10452,7 @@ import org.slf4j.LoggerFactory;
     public boolean stopTabletServers; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       STOP_TABLET_SERVERS((short)2, "stopTabletServers");
@@ -11010,7 +11010,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -11372,7 +11372,7 @@ import org.slf4j.LoggerFactory;
     public boolean force; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       TABLET_SERVER((short)2, "tabletServer"),
@@ -12028,7 +12028,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -12390,7 +12390,7 @@ import org.slf4j.LoggerFactory;
     public String value; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)4, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       PROPERTY((short)2, "property"),
@@ -13048,7 +13048,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -13408,7 +13408,7 @@ import org.slf4j.LoggerFactory;
     public String property; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       PROPERTY((short)2, "property");
@@ -13968,7 +13968,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -14326,7 +14326,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.security.thrift.TCredentials credentials; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       CREDENTIALS((short)1, "credentials");
 
@@ -14790,7 +14790,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -15255,7 +15255,7 @@ import org.slf4j.LoggerFactory;
     public TabletSplit split; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)4, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       SERVER_NAME((short)2, "serverName"),
@@ -15930,7 +15930,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.data.thrift.TKeyExtent tablet; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)5, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       SERVER_NAME((short)2, "serverName"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterGoalState.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterGoalState.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterGoalState.java
index 0cf5f15..f436454 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterGoalState.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterGoalState.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum MasterGoalState implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum MasterGoalState implements org.apache.thrift.TEnum {
   CLEAN_STOP(0),
   SAFE_MODE(1),
   NORMAL(2);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterMonitorInfo.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterMonitorInfo.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterMonitorInfo.java
index bd37d3e..990fc89 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterMonitorInfo.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterMonitorInfo.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class MasterMonitorInfo implements org.apache.thrift.TBase<MasterMonitorInfo, MasterMonitorInfo._Fields>, java.io.Serializable, Cloneable, Comparable<MasterMonitorInfo> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class MasterMonitorInfo implements org.apache.thrift.TBase<MasterMonitorInfo, MasterMonitorInfo._Fields>, java.io.Serializable, Cloneable, Comparable<MasterMonitorInfo> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("MasterMonitorInfo");
 
   private static final org.apache.thrift.protocol.TField TABLE_MAP_FIELD_DESC = new org.apache.thrift.protocol.TField("tableMap", org.apache.thrift.protocol.TType.MAP, (short)1);
@@ -84,7 +84,7 @@ import org.slf4j.LoggerFactory;
   public List<DeadServer> deadTabletServers; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     TABLE_MAP((short)1, "tableMap"),
     T_SERVER_INFO((short)2, "tServerInfo"),
     BAD_TSERVERS((short)3, "badTServers"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterState.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterState.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterState.java
index f479fb5..1d63305 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterState.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/MasterState.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum MasterState implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum MasterState implements org.apache.thrift.TEnum {
   INITIAL(0),
   HAVE_LOCK(1),
   SAFE_MODE(2),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/RecoveryException.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/RecoveryException.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/RecoveryException.java
index afb7422..025cced 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/RecoveryException.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/RecoveryException.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class RecoveryException extends TException implements org.apache.thrift.TBase<RecoveryException, RecoveryException._Fields>, java.io.Serializable, Cloneable, Comparable<RecoveryException> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class RecoveryException extends TException implements org.apache.thrift.TBase<RecoveryException, RecoveryException._Fields>, java.io.Serializable, Cloneable, Comparable<RecoveryException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("RecoveryException");
 
   private static final org.apache.thrift.protocol.TField WHY_FIELD_DESC = new org.apache.thrift.protocol.TField("why", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public String why; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     WHY((short)1, "why");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/RecoveryStatus.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/RecoveryStatus.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/RecoveryStatus.java
index 0d14d31..3ffcb03 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/RecoveryStatus.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/RecoveryStatus.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class RecoveryStatus implements org.apache.thrift.TBase<RecoveryStatus, RecoveryStatus._Fields>, java.io.Serializable, Cloneable, Comparable<RecoveryStatus> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class RecoveryStatus implements org.apache.thrift.TBase<RecoveryStatus, RecoveryStatus._Fields>, java.io.Serializable, Cloneable, Comparable<RecoveryStatus> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("RecoveryStatus");
 
   private static final org.apache.thrift.protocol.TField NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("name", org.apache.thrift.protocol.TType.STRING, (short)2);
@@ -66,7 +66,7 @@ import org.slf4j.LoggerFactory;
   public double progress; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     NAME((short)2, "name"),
     RUNTIME((short)5, "runtime"),
     PROGRESS((short)6, "progress");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/TableInfo.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/TableInfo.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/TableInfo.java
index a40df23..3c919cd 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/TableInfo.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/TableInfo.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TableInfo implements org.apache.thrift.TBase<TableInfo, TableInfo._Fields>, java.io.Serializable, Cloneable, Comparable<TableInfo> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TableInfo implements org.apache.thrift.TBase<TableInfo, TableInfo._Fields>, java.io.Serializable, Cloneable, Comparable<TableInfo> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TableInfo");
 
   private static final org.apache.thrift.protocol.TField RECS_FIELD_DESC = new org.apache.thrift.protocol.TField("recs", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -84,7 +84,7 @@ import org.slf4j.LoggerFactory;
   public double scanRate; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     RECS((short)1, "recs"),
     RECS_IN_MEMORY((short)2, "recsInMemory"),
     TABLETS((short)3, "tablets"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletLoadState.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletLoadState.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletLoadState.java
index f951c72..97338cc 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletLoadState.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletLoadState.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum TabletLoadState implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum TabletLoadState implements org.apache.thrift.TEnum {
   LOADED(0),
   LOAD_FAILURE(1),
   UNLOADED(2),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletServerStatus.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletServerStatus.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletServerStatus.java
index 6348537..1f709fb 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletServerStatus.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletServerStatus.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TabletServerStatus implements org.apache.thrift.TBase<TabletServerStatus, TabletServerStatus._Fields>, java.io.Serializable, Cloneable, Comparable<TabletServerStatus> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TabletServerStatus implements org.apache.thrift.TBase<TabletServerStatus, TabletServerStatus._Fields>, java.io.Serializable, Cloneable, Comparable<TabletServerStatus> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TabletServerStatus");
 
   private static final org.apache.thrift.protocol.TField TABLE_MAP_FIELD_DESC = new org.apache.thrift.protocol.TField("tableMap", org.apache.thrift.protocol.TType.MAP, (short)1);
@@ -82,7 +82,7 @@ import org.slf4j.LoggerFactory;
   public List<RecoveryStatus> logSorts; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     TABLE_MAP((short)1, "tableMap"),
     LAST_CONTACT((short)2, "lastContact"),
     NAME((short)3, "name"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletSplit.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletSplit.java b/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletSplit.java
index 2eb671c..bd529b9 100644
--- a/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletSplit.java
+++ b/core/src/main/java/org/apache/accumulo/core/master/thrift/TabletSplit.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TabletSplit implements org.apache.thrift.TBase<TabletSplit, TabletSplit._Fields>, java.io.Serializable, Cloneable, Comparable<TabletSplit> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TabletSplit implements org.apache.thrift.TBase<TabletSplit, TabletSplit._Fields>, java.io.Serializable, Cloneable, Comparable<TabletSplit> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TabletSplit");
 
   private static final org.apache.thrift.protocol.TField OLD_TABLET_FIELD_DESC = new org.apache.thrift.protocol.TField("oldTablet", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -64,7 +64,7 @@ import org.slf4j.LoggerFactory;
   public List<org.apache.accumulo.core.data.thrift.TKeyExtent> newTablets; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     OLD_TABLET((short)1, "oldTablet"),
     NEW_TABLETS((short)2, "newTablets");
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/security/thrift/TCredentials.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/security/thrift/TCredentials.java b/core/src/main/java/org/apache/accumulo/core/security/thrift/TCredentials.java
index 8d3a3e2..0bbd241 100644
--- a/core/src/main/java/org/apache/accumulo/core/security/thrift/TCredentials.java
+++ b/core/src/main/java/org/apache/accumulo/core/security/thrift/TCredentials.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TCredentials implements org.apache.thrift.TBase<TCredentials, TCredentials._Fields>, java.io.Serializable, Cloneable, Comparable<TCredentials> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TCredentials implements org.apache.thrift.TBase<TCredentials, TCredentials._Fields>, java.io.Serializable, Cloneable, Comparable<TCredentials> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TCredentials");
 
   private static final org.apache.thrift.protocol.TField PRINCIPAL_FIELD_DESC = new org.apache.thrift.protocol.TField("principal", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -68,7 +68,7 @@ import org.slf4j.LoggerFactory;
   public String instanceId; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     PRINCIPAL((short)1, "principal"),
     TOKEN_CLASS_NAME((short)2, "tokenClassName"),
     TOKEN((short)3, "token"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActionStats.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActionStats.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActionStats.java
index 0cb5c08..86a502b 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActionStats.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActionStats.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ActionStats implements org.apache.thrift.TBase<ActionStats, ActionStats._Fields>, java.io.Serializable, Cloneable, Comparable<ActionStats> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ActionStats implements org.apache.thrift.TBase<ActionStats, ActionStats._Fields>, java.io.Serializable, Cloneable, Comparable<ActionStats> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ActionStats");
 
   private static final org.apache.thrift.protocol.TField STATUS_FIELD_DESC = new org.apache.thrift.protocol.TField("status", org.apache.thrift.protocol.TType.I32, (short)1);
@@ -76,7 +76,7 @@ import org.slf4j.LoggerFactory;
   public double queueSumDev; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     STATUS((short)1, "status"),
     ELAPSED((short)2, "elapsed"),
     NUM((short)3, "num"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActiveCompaction.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActiveCompaction.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActiveCompaction.java
index c2eddd1..9c1977d 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActiveCompaction.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActiveCompaction.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ActiveCompaction implements org.apache.thrift.TBase<ActiveCompaction, ActiveCompaction._Fields>, java.io.Serializable, Cloneable, Comparable<ActiveCompaction> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ActiveCompaction implements org.apache.thrift.TBase<ActiveCompaction, ActiveCompaction._Fields>, java.io.Serializable, Cloneable, Comparable<ActiveCompaction> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ActiveCompaction");
 
   private static final org.apache.thrift.protocol.TField EXTENT_FIELD_DESC = new org.apache.thrift.protocol.TField("extent", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -90,7 +90,7 @@ import org.slf4j.LoggerFactory;
   public Map<String,Map<String,String>> ssio; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     EXTENT((short)1, "extent"),
     AGE((short)2, "age"),
     INPUT_FILES((short)3, "inputFiles"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActiveScan.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActiveScan.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActiveScan.java
index 5371fd8..fe389e4 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActiveScan.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ActiveScan.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ActiveScan implements org.apache.thrift.TBase<ActiveScan, ActiveScan._Fields>, java.io.Serializable, Cloneable, Comparable<ActiveScan> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ActiveScan implements org.apache.thrift.TBase<ActiveScan, ActiveScan._Fields>, java.io.Serializable, Cloneable, Comparable<ActiveScan> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ActiveScan");
 
   private static final org.apache.thrift.protocol.TField CLIENT_FIELD_DESC = new org.apache.thrift.protocol.TField("client", org.apache.thrift.protocol.TType.STRING, (short)2);
@@ -94,7 +94,7 @@ import org.slf4j.LoggerFactory;
   public long scanId; // optional
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     CLIENT((short)2, "client"),
     USER((short)3, "user"),
     TABLE_ID((short)4, "tableId"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/CompactionReason.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/CompactionReason.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/CompactionReason.java
index 36cce96..591dffd 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/CompactionReason.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/CompactionReason.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum CompactionReason implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum CompactionReason implements org.apache.thrift.TEnum {
   USER(0),
   SYSTEM(1),
   CHOP(2),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/CompactionType.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/CompactionType.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/CompactionType.java
index b4fdf68..f2f2cd6 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/CompactionType.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/CompactionType.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum CompactionType implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum CompactionType implements org.apache.thrift.TEnum {
   MINOR(0),
   MERGE(1),
   MAJOR(2),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ConstraintViolationException.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ConstraintViolationException.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ConstraintViolationException.java
index 9515903..7a94159 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ConstraintViolationException.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ConstraintViolationException.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class ConstraintViolationException extends TException implements org.apache.thrift.TBase<ConstraintViolationException, ConstraintViolationException._Fields>, java.io.Serializable, Cloneable, Comparable<ConstraintViolationException> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class ConstraintViolationException extends TException implements org.apache.thrift.TBase<ConstraintViolationException, ConstraintViolationException._Fields>, java.io.Serializable, Cloneable, Comparable<ConstraintViolationException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ConstraintViolationException");
 
   private static final org.apache.thrift.protocol.TField VIOLATION_SUMMARIES_FIELD_DESC = new org.apache.thrift.protocol.TField("violationSummaries", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public List<org.apache.accumulo.core.data.thrift.TConstraintViolationSummary> violationSummaries; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     VIOLATION_SUMMARIES((short)1, "violationSummaries");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/IteratorConfig.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/IteratorConfig.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/IteratorConfig.java
index 1a05071..9db0608 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/IteratorConfig.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/IteratorConfig.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class IteratorConfig implements org.apache.thrift.TBase<IteratorConfig, IteratorConfig._Fields>, java.io.Serializable, Cloneable, Comparable<IteratorConfig> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class IteratorConfig implements org.apache.thrift.TBase<IteratorConfig, IteratorConfig._Fields>, java.io.Serializable, Cloneable, Comparable<IteratorConfig> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("IteratorConfig");
 
   private static final org.apache.thrift.protocol.TField ITERATORS_FIELD_DESC = new org.apache.thrift.protocol.TField("iterators", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public List<TIteratorSetting> iterators; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     ITERATORS((short)1, "iterators");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/NoSuchScanIDException.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/NoSuchScanIDException.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/NoSuchScanIDException.java
index 79f664f..c0dc02b 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/NoSuchScanIDException.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/NoSuchScanIDException.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class NoSuchScanIDException extends TException implements org.apache.thrift.TBase<NoSuchScanIDException, NoSuchScanIDException._Fields>, java.io.Serializable, Cloneable, Comparable<NoSuchScanIDException> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class NoSuchScanIDException extends TException implements org.apache.thrift.TBase<NoSuchScanIDException, NoSuchScanIDException._Fields>, java.io.Serializable, Cloneable, Comparable<NoSuchScanIDException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("NoSuchScanIDException");
 
 
@@ -60,7 +60,7 @@ import org.slf4j.LoggerFactory;
 
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
 ;
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/NotServingTabletException.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/NotServingTabletException.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/NotServingTabletException.java
index c43b5c0..ef87937 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/NotServingTabletException.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/NotServingTabletException.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class NotServingTabletException extends TException implements org.apache.thrift.TBase<NotServingTabletException, NotServingTabletException._Fields>, java.io.Serializable, Cloneable, Comparable<NotServingTabletException> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class NotServingTabletException extends TException implements org.apache.thrift.TBase<NotServingTabletException, NotServingTabletException._Fields>, java.io.Serializable, Cloneable, Comparable<NotServingTabletException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("NotServingTabletException");
 
   private static final org.apache.thrift.protocol.TField EXTENT_FIELD_DESC = new org.apache.thrift.protocol.TField("extent", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public org.apache.accumulo.core.data.thrift.TKeyExtent extent; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     EXTENT((short)1, "extent");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ScanState.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ScanState.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ScanState.java
index c676599..5bb6857 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ScanState.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ScanState.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum ScanState implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum ScanState implements org.apache.thrift.TEnum {
   IDLE(0),
   RUNNING(1),
   QUEUED(2);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ScanType.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ScanType.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ScanType.java
index cb333a5..34d7ac5 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ScanType.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/ScanType.java
@@ -27,7 +27,7 @@ import java.util.Map;
 import java.util.HashMap;
 import org.apache.thrift.TEnum;
 
-@SuppressWarnings("all") public enum ScanType implements org.apache.thrift.TEnum {
+@SuppressWarnings({"unused"}) public enum ScanType implements org.apache.thrift.TEnum {
   SINGLE(0),
   BATCH(1);
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TIteratorSetting.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TIteratorSetting.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TIteratorSetting.java
index f457311..8eddaba 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TIteratorSetting.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TIteratorSetting.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TIteratorSetting implements org.apache.thrift.TBase<TIteratorSetting, TIteratorSetting._Fields>, java.io.Serializable, Cloneable, Comparable<TIteratorSetting> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TIteratorSetting implements org.apache.thrift.TBase<TIteratorSetting, TIteratorSetting._Fields>, java.io.Serializable, Cloneable, Comparable<TIteratorSetting> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TIteratorSetting");
 
   private static final org.apache.thrift.protocol.TField PRIORITY_FIELD_DESC = new org.apache.thrift.protocol.TField("priority", org.apache.thrift.protocol.TType.I32, (short)1);
@@ -68,7 +68,7 @@ import org.slf4j.LoggerFactory;
   public Map<String,String> properties; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     PRIORITY((short)1, "priority"),
     NAME((short)2, "name"),
     ITERATOR_CLASS((short)3, "iteratorClass"),


[15/25] accumulo git commit: ACCUMULO-3759 More build warnings on Java 8

Posted by ct...@apache.org.
http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TabletClientService.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TabletClientService.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TabletClientService.java
index 2ba7674..3384e00 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TabletClientService.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TabletClientService.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TabletClientService {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TabletClientService {
 
   public interface Iface extends org.apache.accumulo.core.client.impl.thrift.ClientService.Iface {
 
@@ -4336,7 +4336,7 @@ import org.slf4j.LoggerFactory;
     public long readaheadThreshold; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)11, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       EXTENT((short)2, "extent"),
@@ -6034,7 +6034,7 @@ import org.slf4j.LoggerFactory;
     public TooManyFilesException tmfe; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec"),
       NSTE((short)2, "nste"),
@@ -6695,7 +6695,7 @@ import org.slf4j.LoggerFactory;
     public long scanID; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       SCAN_ID((short)1, "scanID");
 
@@ -7156,7 +7156,7 @@ import org.slf4j.LoggerFactory;
     public TooManyFilesException tmfe; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       NSSI((short)1, "nssi"),
       NSTE((short)2, "nste"),
@@ -7817,7 +7817,7 @@ import org.slf4j.LoggerFactory;
     public long scanID; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       SCAN_ID((short)1, "scanID");
 
@@ -8286,7 +8286,7 @@ import org.slf4j.LoggerFactory;
     public boolean waitForWrites; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)8, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       BATCH((short)2, "batch"),
@@ -9681,7 +9681,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -10142,7 +10142,7 @@ import org.slf4j.LoggerFactory;
     public long scanID; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       SCAN_ID((short)1, "scanID");
 
@@ -10599,7 +10599,7 @@ import org.slf4j.LoggerFactory;
     public NoSuchScanIDException nssi; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       NSSI((short)1, "nssi");
 
@@ -11060,7 +11060,7 @@ import org.slf4j.LoggerFactory;
     public long scanID; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       SCAN_ID((short)1, "scanID");
 
@@ -11515,7 +11515,7 @@ import org.slf4j.LoggerFactory;
     public NoSuchScanIDException nssi; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       NSSI((short)1, "nssi");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -11873,7 +11873,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.security.thrift.TCredentials credentials; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       CREDENTIALS((short)1, "credentials");
 
@@ -12337,7 +12337,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -12797,7 +12797,7 @@ import org.slf4j.LoggerFactory;
     public List<org.apache.accumulo.core.data.thrift.TMutation> mutations; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       UPDATE_ID((short)2, "updateID"),
       KEY_EXTENT((short)3, "keyExtent"),
@@ -13509,7 +13509,7 @@ import org.slf4j.LoggerFactory;
     public long updateID; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       UPDATE_ID((short)1, "updateID");
 
@@ -13966,7 +13966,7 @@ import org.slf4j.LoggerFactory;
     public NoSuchScanIDException nssi; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       NSSI((short)1, "nssi");
 
@@ -14431,7 +14431,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.data.thrift.TMutation mutation; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)4, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       KEY_EXTENT((short)2, "keyExtent"),
@@ -15103,7 +15103,7 @@ import org.slf4j.LoggerFactory;
     public ConstraintViolationException cve; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec"),
       NSTE((short)2, "nste"),
       CVE((short)3, "cve");
@@ -15665,7 +15665,7 @@ import org.slf4j.LoggerFactory;
     public String tableID; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)2, "credentials"),
       AUTHORIZATIONS((short)3, "authorizations"),
@@ -16374,7 +16374,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -16839,7 +16839,7 @@ import org.slf4j.LoggerFactory;
     public List<String> symbols; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       SESS_ID((short)2, "sessID"),
       MUTATIONS((short)3, "mutations"),
@@ -17626,7 +17626,7 @@ import org.slf4j.LoggerFactory;
     public NoSuchScanIDException nssi; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       NSSI((short)1, "nssi");
 
@@ -18136,7 +18136,7 @@ import org.slf4j.LoggerFactory;
     public long sessID; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       SESS_ID((short)2, "sessID");
 
@@ -18589,7 +18589,7 @@ import org.slf4j.LoggerFactory;
 
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
 ;
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -18839,7 +18839,7 @@ import org.slf4j.LoggerFactory;
     public long sessID; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       SESS_ID((short)2, "sessID");
 
@@ -19302,7 +19302,7 @@ import org.slf4j.LoggerFactory;
     public boolean setTime; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       TID((short)4, "tid"),
@@ -20143,7 +20143,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -20657,7 +20657,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer splitPoint; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)4, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       EXTENT((short)2, "extent"),
@@ -21333,7 +21333,7 @@ import org.slf4j.LoggerFactory;
     public NotServingTabletException nste; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec"),
       NSTE((short)2, "nste");
 
@@ -21795,7 +21795,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.data.thrift.TKeyExtent extent; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)5, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       LOCK((short)4, "lock"),
@@ -22466,7 +22466,7 @@ import org.slf4j.LoggerFactory;
     public boolean save; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)5, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       LOCK((short)4, "lock"),
@@ -23235,7 +23235,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer endRow; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)4, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       LOCK((short)3, "lock"),
@@ -24117,7 +24117,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.data.thrift.TKeyExtent extent; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)2, "credentials"),
       LOCK((short)3, "lock"),
@@ -24786,7 +24786,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.data.thrift.TKeyExtent extent; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)2, "credentials"),
       LOCK((short)3, "lock"),
@@ -25459,7 +25459,7 @@ import org.slf4j.LoggerFactory;
     public ByteBuffer endRow; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)2, "credentials"),
       LOCK((short)3, "lock"),
@@ -26337,7 +26337,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.security.thrift.TCredentials credentials; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)1, "credentials");
 
@@ -26801,7 +26801,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -27264,7 +27264,7 @@ import org.slf4j.LoggerFactory;
     public String tableId; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       TABLE_ID((short)2, "tableId");
@@ -27826,7 +27826,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -28336,7 +28336,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.security.thrift.TCredentials credentials; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       CREDENTIALS((short)1, "credentials");
 
@@ -28800,7 +28800,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -29263,7 +29263,7 @@ import org.slf4j.LoggerFactory;
     public String lock; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       LOCK((short)2, "lock");
@@ -29823,7 +29823,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SEC((short)1, "sec");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -30183,7 +30183,7 @@ import org.slf4j.LoggerFactory;
     public String lock; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)3, "tinfo"),
       CREDENTIALS((short)1, "credentials"),
       LOCK((short)2, "lock");
@@ -30745,7 +30745,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.security.thrift.TCredentials credentials; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       CREDENTIALS((short)1, "credentials");
 
@@ -31209,7 +31209,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -31719,7 +31719,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.security.thrift.TCredentials credentials; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)2, "tinfo"),
       CREDENTIALS((short)1, "credentials");
 
@@ -32183,7 +32183,7 @@ import org.slf4j.LoggerFactory;
     public org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException sec; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success"),
       SEC((short)1, "sec");
 
@@ -32695,7 +32695,7 @@ import org.slf4j.LoggerFactory;
     public List<String> filenames; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       CREDENTIALS((short)2, "credentials"),
       FILENAMES((short)3, "filenames");

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TabletStats.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TabletStats.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TabletStats.java
index 8989fe5..310d3b6 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TabletStats.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TabletStats.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TabletStats implements org.apache.thrift.TBase<TabletStats, TabletStats._Fields>, java.io.Serializable, Cloneable, Comparable<TabletStats> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TabletStats implements org.apache.thrift.TBase<TabletStats, TabletStats._Fields>, java.io.Serializable, Cloneable, Comparable<TabletStats> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TabletStats");
 
   private static final org.apache.thrift.protocol.TField EXTENT_FIELD_DESC = new org.apache.thrift.protocol.TField("extent", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -76,7 +76,7 @@ import org.slf4j.LoggerFactory;
   public long splitCreationTime; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     EXTENT((short)1, "extent"),
     MAJORS((short)2, "majors"),
     MINORS((short)3, "minors"),

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TooManyFilesException.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TooManyFilesException.java b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TooManyFilesException.java
index cc4c3e8..203597a 100644
--- a/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TooManyFilesException.java
+++ b/core/src/main/java/org/apache/accumulo/core/tabletserver/thrift/TooManyFilesException.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class TooManyFilesException extends TException implements org.apache.thrift.TBase<TooManyFilesException, TooManyFilesException._Fields>, java.io.Serializable, Cloneable, Comparable<TooManyFilesException> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class TooManyFilesException extends TException implements org.apache.thrift.TBase<TooManyFilesException, TooManyFilesException._Fields>, java.io.Serializable, Cloneable, Comparable<TooManyFilesException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TooManyFilesException");
 
   private static final org.apache.thrift.protocol.TField EXTENT_FIELD_DESC = new org.apache.thrift.protocol.TField("extent", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public org.apache.accumulo.core.data.thrift.TKeyExtent extent; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     EXTENT((short)1, "extent");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/core/src/main/scripts/generate-thrift.sh
----------------------------------------------------------------------
diff --git a/core/src/main/scripts/generate-thrift.sh b/core/src/main/scripts/generate-thrift.sh
index ee5bb8e..8c2a623 100755
--- a/core/src/main/scripts/generate-thrift.sh
+++ b/core/src/main/scripts/generate-thrift.sh
@@ -26,23 +26,23 @@
 #   INCLUDED_MODULES should be an array that includes other Maven modules with src/main/thrift directories
 #   Use INCLUDED_MODULES=(-) in calling scripts that require no other modules
 # ========================================================================================================================
-[ -z $REQUIRED_THRIFT_VERSION ] && REQUIRED_THRIFT_VERSION='0.9.1'
-[ -z $INCLUDED_MODULES ]        && INCLUDED_MODULES=(../trace)
-[ -z $BASE_OUTPUT_PACKAGE ]     && BASE_OUTPUT_PACKAGE='org.apache.accumulo.core'
-[ -z $PACKAGES_TO_GENERATE ]    && PACKAGES_TO_GENERATE=(gc master tabletserver security client.impl data)
-[ -z $BUILD_DIR ]               && BUILD_DIR='target'
-[ -z $LANGUAGES_TO_GENERATE ]   && LANGUAGES_TO_GENERATE=(java)
-[ -z $FINAL_DIR ]               && FINAL_DIR='src/main'
+[[ -z $REQUIRED_THRIFT_VERSION ]] && REQUIRED_THRIFT_VERSION='0.9.1'
+[[ -z $INCLUDED_MODULES ]]        && INCLUDED_MODULES=(../trace)
+[[ -z $BASE_OUTPUT_PACKAGE ]]     && BASE_OUTPUT_PACKAGE='org.apache.accumulo.core'
+[[ -z $PACKAGES_TO_GENERATE ]]    && PACKAGES_TO_GENERATE=(gc master tabletserver security client.impl data)
+[[ -z $BUILD_DIR ]]               && BUILD_DIR='target'
+[[ -z $LANGUAGES_TO_GENERATE ]]   && LANGUAGES_TO_GENERATE=(java)
+[[ -z $FINAL_DIR ]]               && FINAL_DIR='src/main'
 # ========================================================================================================================
 
 fail() {
-  echo $@
+  echo "$@"
   exit 1
 }
 
 # Test to see if we have thrift installed
-VERSION=$(thrift -version 2>/dev/null | grep -F "${REQUIRED_THRIFT_VERSION}" |  wc -l)
-if [ "$VERSION" -ne 1 ] ; then 
+VERSION=$(thrift -version 2>/dev/null | grep -F "${REQUIRED_THRIFT_VERSION}" |  wc -l | sed -e 's/^ *//' -e 's/ *$//')
+if [[ "${VERSION}" != '1' ]] ; then
   # Nope: bail
   echo "****************************************************"
   echo "*** thrift is not available"
@@ -65,15 +65,17 @@ THRIFT_ARGS="${THRIFT_ARGS} -o $BUILD_DIR"
 mkdir -p $BUILD_DIR
 rm -rf $BUILD_DIR/gen-java
 for f in src/main/thrift/*.thrift; do
-  thrift ${THRIFT_ARGS} --gen java $f || fail unable to generate java thrift classes
-  thrift ${THRIFT_ARGS} --gen py $f || fail unable to generate python thrift classes
-  thrift ${THRIFT_ARGS} --gen rb $f || fail unable to generate ruby thrift classes
-  thrift ${THRIFT_ARGS} --gen cpp $f || fail unable to generate cpp thrift classes
+  thrift ${THRIFT_ARGS} --gen java "$f" || fail unable to generate java thrift classes
+  thrift ${THRIFT_ARGS} --gen py "$f" || fail unable to generate python thrift classes
+  thrift ${THRIFT_ARGS} --gen rb "$f" || fail unable to generate ruby thrift classes
+  thrift ${THRIFT_ARGS} --gen cpp "$f" || fail unable to generate cpp thrift classes
 done
 
 # For all generated thrift code, suppress all warnings and add the LICENSE header
-find $BUILD_DIR/gen-java -name '*.java' -print0 | xargs -0 sed -i.orig -e 's/public class /@SuppressWarnings("all") public class /'
-find $BUILD_DIR/gen-java -name '*.java' -print0 | xargs -0 sed -i.orig -e 's/public enum /@SuppressWarnings("all") public enum /'
+cs='@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"})'
+es='@SuppressWarnings({"unused"})'
+find $BUILD_DIR/gen-java -name '*.java' -print0 | xargs -0 sed -i.orig -e 's/\(public class [A-Z]\)/'"$cs"' \1/'
+find $BUILD_DIR/gen-java -name '*.java' -print0 | xargs -0 sed -i.orig -e 's/\(public enum [A-Z]\)/'"$es"' \1/'
 
 for lang in "${LANGUAGES_TO_GENERATE[@]}"; do
   case $lang in
@@ -109,10 +111,10 @@ for lang in "${LANGUAGES_TO_GENERATE[@]}"; do
       continue
       ;;
   esac
-  
-  for file in ${FILE_SUFFIX[@]}; do
+
+  for file in "${FILE_SUFFIX[@]}"; do
     for f in $(find $BUILD_DIR/gen-$lang -name "*$file"); do
-      cat - $f >${f}-with-license <<EOF
+      cat - "$f" > "${f}-with-license" <<EOF
 ${PREFIX}${LINE_NOTATION} Licensed to the Apache Software Foundation (ASF) under one or more
 ${LINE_NOTATION} contributor license agreements.  See the NOTICE file distributed with
 ${LINE_NOTATION} this work for additional information regarding copyright ownership.
@@ -135,7 +137,7 @@ done
 # For every generated java file, compare it with the version-controlled one, and copy the ones that have changed into place
 for d in "${PACKAGES_TO_GENERATE[@]}"; do
   for lang in "${LANGUAGES_TO_GENERATE[@]}"; do
-    case $lang in
+    case "$lang" in
       cpp)
         SDIR="${BUILD_DIR}/gen-$lang/"
         DDIR="${FINAL_DIR}/cpp/"
@@ -161,11 +163,11 @@ for d in "${PACKAGES_TO_GENERATE[@]}"; do
         ;;
     esac
     mkdir -p "$DDIR"
-    for file in ${FILE_SUFFIX[@]}; do
-      for f in `find $SDIR -name *$file`; do
-        DEST="$DDIR/`basename $f`"
+    for file in "${FILE_SUFFIX[@]}"; do
+      for f in $(find $SDIR -name *$file); do
+        DEST="$DDIR/$(basename $f)"
         if ! cmp -s "${f}-with-license" "${DEST}" ; then
-          echo cp -f "${f}-with-license" "${DEST}" 
+          echo cp -f "${f}-with-license" "${DEST}"
           cp -f "${f}-with-license" "${DEST}" || fail unable to copy files to java workspace
         fi
       done

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index 3389795..9249a5b 100644
--- a/pom.xml
+++ b/pom.xml
@@ -118,6 +118,8 @@
     <accumulo.release.version>${project.version}</accumulo.release.version>
     <!-- bouncycastle version for test dependencies -->
     <bouncycastle.version>1.50</bouncycastle.version>
+    <!-- findbugs-maven-plugin won't work on jdk8 or later; set to 3.0.0 or newer -->
+    <findbugs.version>2.5.5</findbugs.version>
     <!-- surefire/failsafe plugin option -->
     <forkCount>1</forkCount>
     <!-- overwritten in profiles hadoop-1 or hadoop-2 -->
@@ -499,7 +501,7 @@
         <plugin>
           <groupId>org.codehaus.mojo</groupId>
           <artifactId>findbugs-maven-plugin</artifactId>
-          <version>2.5.5</version>
+          <version>${findbugs.version}</version>
           <configuration>
             <xmlOutput>true</xmlOutput>
             <effort>Max</effort>
@@ -1141,7 +1143,7 @@
       <plugin>
         <groupId>org.codehaus.mojo</groupId>
         <artifactId>findbugs-maven-plugin</artifactId>
-        <version>2.5.3</version>
+        <version>${findbugs.version}</version>
         <configuration>
           <excludeFilterFile>contrib/findbugs-exclude.xml</excludeFilterFile>
           <findbugsXmlOutput>true</findbugsXmlOutput>

http://git-wip-us.apache.org/repos/asf/accumulo/blob/bbcc6da4/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloException.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloException.java b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloException.java
index 0be034c..724a92e 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloException.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/thrift/AccumuloException.java
@@ -48,7 +48,7 @@ import java.util.Arrays;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-@SuppressWarnings("all") public class AccumuloException extends TException implements org.apache.thrift.TBase<AccumuloException, AccumuloException._Fields>, java.io.Serializable, Cloneable, Comparable<AccumuloException> {
+@SuppressWarnings({"unchecked", "serial", "rawtypes", "unused"}) public class AccumuloException extends TException implements org.apache.thrift.TBase<AccumuloException, AccumuloException._Fields>, java.io.Serializable, Cloneable, Comparable<AccumuloException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("AccumuloException");
 
   private static final org.apache.thrift.protocol.TField MSG_FIELD_DESC = new org.apache.thrift.protocol.TField("msg", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -62,7 +62,7 @@ import org.slf4j.LoggerFactory;
   public String msg; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     MSG((short)1, "msg");
 
     private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();