You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@accumulo.apache.org by kt...@apache.org on 2015/04/22 18:29:18 UTC

accumulo git commit: ACCUMULO-3657 rename TabletID to TabletId

Repository: accumulo
Updated Branches:
  refs/heads/1.7 f76acc6a0 -> ac08cc4d2


ACCUMULO-3657 rename TabletID to TabletId


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

Branch: refs/heads/1.7
Commit: ac08cc4d218be7028e6fb51f4518b4fd783816f9
Parents: f76acc6
Author: Keith Turner <kt...@apache.org>
Authored: Wed Apr 22 11:51:30 2015 -0400
Committer: Keith Turner <kt...@apache.org>
Committed: Wed Apr 22 11:55:05 2015 -0400

----------------------------------------------------------------------
 .../core/client/MutationsRejectedException.java |  24 ++---
 .../core/client/admin/ActiveCompaction.java     |   4 +-
 .../accumulo/core/client/admin/ActiveScan.java  |   4 +-
 .../core/client/impl/ActiveCompactionImpl.java  |   8 +-
 .../core/client/impl/ActiveScanImpl.java        |   8 +-
 .../client/impl/TabletServerBatchWriter.java    |   8 +-
 .../client/mapred/AccumuloOutputFormat.java     |   4 +-
 .../client/mapreduce/AccumuloOutputFormat.java  |   4 +-
 .../apache/accumulo/core/data/KeyExtent.java    |   2 +-
 .../org/apache/accumulo/core/data/TabletID.java |  29 ------
 .../org/apache/accumulo/core/data/TabletId.java |  31 ++++++
 .../accumulo/core/data/impl/TabletIDImpl.java   | 100 -------------------
 .../accumulo/core/data/impl/TabletIdImpl.java   | 100 +++++++++++++++++++
 .../simple/client/RandomBatchWriter.java        |   4 +-
 .../org/apache/accumulo/proxy/ProxyServer.java  |   6 +-
 .../accumulo/shell/commands/InsertCommand.java  |   4 +-
 .../org/apache/accumulo/test/TestIngest.java    |   4 +-
 17 files changed, 173 insertions(+), 171 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/ac08cc4d/core/src/main/java/org/apache/accumulo/core/client/MutationsRejectedException.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/MutationsRejectedException.java b/core/src/main/java/org/apache/accumulo/core/client/MutationsRejectedException.java
index 1a7e1ac..d046991 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/MutationsRejectedException.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/MutationsRejectedException.java
@@ -28,8 +28,8 @@ import java.util.Set;
 import org.apache.accumulo.core.client.impl.Tables;
 import org.apache.accumulo.core.client.security.SecurityErrorCode;
 import org.apache.accumulo.core.data.ConstraintViolationSummary;
-import org.apache.accumulo.core.data.TabletID;
-import org.apache.accumulo.core.data.impl.TabletIDImpl;
+import org.apache.accumulo.core.data.TabletId;
+import org.apache.accumulo.core.data.impl.TabletIdImpl;
 
 import com.google.common.base.Function;
 import com.google.common.collect.Collections2;
@@ -42,7 +42,7 @@ public class MutationsRejectedException extends AccumuloException {
   private static final long serialVersionUID = 1L;
 
   private List<ConstraintViolationSummary> cvsl;
-  private Map<TabletID,Set<SecurityErrorCode>> af;
+  private Map<TabletId,Set<SecurityErrorCode>> af;
   private Collection<String> es;
   private int unknownErrors;
 
@@ -73,7 +73,7 @@ public class MutationsRejectedException extends AccumuloException {
     super("# constraint violations : " + cvsList.size() + "  security codes: " + hashMap.values() + "  # server errors " + serverSideErrors.size()
         + " # exceptions " + unknownErrors, cause);
     this.cvsl = cvsList;
-    this.af = transformKeys(hashMap, TabletIDImpl.KE_2_TID_OLD);
+    this.af = transformKeys(hashMap, TabletIdImpl.KE_2_TID_OLD);
     this.es = serverSideErrors;
     this.unknownErrors = unknownErrors;
   }
@@ -93,10 +93,10 @@ public class MutationsRejectedException extends AccumuloException {
   @Deprecated
   public MutationsRejectedException(Instance instance, List<ConstraintViolationSummary> cvsList, HashMap<org.apache.accumulo.core.data.KeyExtent,Set<SecurityErrorCode>> hashMap,
       Collection<String> serverSideErrors, int unknownErrors, Throwable cause) {
-    super("# constraint violations : " + cvsList.size() + "  security codes: " + format(transformKeys(hashMap, TabletIDImpl.KE_2_TID_OLD), instance)
+    super("# constraint violations : " + cvsList.size() + "  security codes: " + format(transformKeys(hashMap, TabletIdImpl.KE_2_TID_OLD), instance)
         + "  # server errors " + serverSideErrors.size() + " # exceptions " + unknownErrors, cause);
     this.cvsl = cvsList;
-    this.af = transformKeys(hashMap, TabletIDImpl.KE_2_TID_OLD);
+    this.af = transformKeys(hashMap, TabletIdImpl.KE_2_TID_OLD);
     this.es = serverSideErrors;
     this.unknownErrors = unknownErrors;
   }
@@ -114,7 +114,7 @@ public class MutationsRejectedException extends AccumuloException {
    *
    * @since 1.7.0
    */
-  public MutationsRejectedException(Instance instance, List<ConstraintViolationSummary> cvsList, Map<TabletID,Set<SecurityErrorCode>> hashMap,
+  public MutationsRejectedException(Instance instance, List<ConstraintViolationSummary> cvsList, Map<TabletId,Set<SecurityErrorCode>> hashMap,
       Collection<String> serverSideErrors, int unknownErrors, Throwable cause) {
     super("# constraint violations : " + cvsList.size() + "  security codes: " + format(hashMap, instance) + "  # server errors " + serverSideErrors.size()
         + " # exceptions " + unknownErrors, cause);
@@ -124,10 +124,10 @@ public class MutationsRejectedException extends AccumuloException {
     this.unknownErrors = unknownErrors;
   }
 
-  private static String format(Map<TabletID,Set<SecurityErrorCode>> hashMap, Instance instance) {
+  private static String format(Map<TabletId,Set<SecurityErrorCode>> hashMap, Instance instance) {
     Map<String,Set<SecurityErrorCode>> result = new HashMap<String,Set<SecurityErrorCode>>();
 
-    for (Entry<TabletID,Set<SecurityErrorCode>> entry : hashMap.entrySet()) {
+    for (Entry<TabletId,Set<SecurityErrorCode>> entry : hashMap.entrySet()) {
       String tableInfo = Tables.getPrintableTableInfoFromId(instance, entry.getKey().getTableId().toString());
 
       if (!result.containsKey(tableInfo)) {
@@ -153,7 +153,7 @@ public class MutationsRejectedException extends AccumuloException {
    */
   @Deprecated
   public List<org.apache.accumulo.core.data.KeyExtent> getAuthorizationFailures() {
-    return new ArrayList<org.apache.accumulo.core.data.KeyExtent>(Collections2.transform(af.keySet(), TabletIDImpl.TID_2_KE_OLD));
+    return new ArrayList<org.apache.accumulo.core.data.KeyExtent>(Collections2.transform(af.keySet(), TabletIdImpl.TID_2_KE_OLD));
   }
 
   /**
@@ -163,13 +163,13 @@ public class MutationsRejectedException extends AccumuloException {
    */
   @Deprecated
   public Map<org.apache.accumulo.core.data.KeyExtent,Set<SecurityErrorCode>> getAuthorizationFailuresMap() {
-    return transformKeys(af, TabletIDImpl.TID_2_KE_OLD);
+    return transformKeys(af, TabletIdImpl.TID_2_KE_OLD);
   }
 
   /**
    * @return the internal mapping of TabletID to SecurityErrorCodes
    */
-  public Map<TabletID,Set<SecurityErrorCode>> getSecurityErrorCodes(){
+  public Map<TabletId,Set<SecurityErrorCode>> getSecurityErrorCodes(){
     return af;
   }
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/ac08cc4d/core/src/main/java/org/apache/accumulo/core/client/admin/ActiveCompaction.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/ActiveCompaction.java b/core/src/main/java/org/apache/accumulo/core/client/admin/ActiveCompaction.java
index 8f3a5aa..89d30b1 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/admin/ActiveCompaction.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/admin/ActiveCompaction.java
@@ -20,7 +20,7 @@ import java.util.List;
 
 import org.apache.accumulo.core.client.IteratorSetting;
 import org.apache.accumulo.core.client.TableNotFoundException;
-import org.apache.accumulo.core.data.TabletID;
+import org.apache.accumulo.core.data.TabletId;
 
 /**
  *
@@ -87,7 +87,7 @@ public abstract class ActiveCompaction {
    * @return tablet thats is compacting
    * @since 1.7.0
    */
-  public abstract TabletID getTablet();
+  public abstract TabletId getTablet();
 
   /**
    * @return how long the compaction has been running in milliseconds

http://git-wip-us.apache.org/repos/asf/accumulo/blob/ac08cc4d/core/src/main/java/org/apache/accumulo/core/client/admin/ActiveScan.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/admin/ActiveScan.java b/core/src/main/java/org/apache/accumulo/core/client/admin/ActiveScan.java
index 4621399..81bb1cc 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/admin/ActiveScan.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/admin/ActiveScan.java
@@ -20,7 +20,7 @@ import java.util.List;
 import java.util.Map;
 
 import org.apache.accumulo.core.data.Column;
-import org.apache.accumulo.core.data.TabletID;
+import org.apache.accumulo.core.data.TabletId;
 import org.apache.accumulo.core.security.Authorizations;
 
 /**
@@ -74,7 +74,7 @@ public abstract class ActiveScan {
    * @return tablet the scan is running against, if a batch scan may be one of many or null
    * @since 1.7.0
    */
-  public abstract TabletID getTablet();
+  public abstract TabletId getTablet();
 
   /**
    * @return columns requested by the scan

http://git-wip-us.apache.org/repos/asf/accumulo/blob/ac08cc4d/core/src/main/java/org/apache/accumulo/core/client/impl/ActiveCompactionImpl.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/ActiveCompactionImpl.java b/core/src/main/java/org/apache/accumulo/core/client/impl/ActiveCompactionImpl.java
index 6dbac73..bb7366b 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/ActiveCompactionImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/ActiveCompactionImpl.java
@@ -24,9 +24,9 @@ import org.apache.accumulo.core.client.Instance;
 import org.apache.accumulo.core.client.IteratorSetting;
 import org.apache.accumulo.core.client.TableNotFoundException;
 import org.apache.accumulo.core.client.admin.ActiveCompaction;
-import org.apache.accumulo.core.data.TabletID;
+import org.apache.accumulo.core.data.TabletId;
 import org.apache.accumulo.core.data.impl.KeyExtent;
-import org.apache.accumulo.core.data.impl.TabletIDImpl;
+import org.apache.accumulo.core.data.impl.TabletIdImpl;
 import org.apache.accumulo.core.data.thrift.IterInfo;
 
 /**
@@ -58,8 +58,8 @@ public class ActiveCompactionImpl extends ActiveCompaction {
   }
 
   @Override
-  public TabletID getTablet() {
-    return new TabletIDImpl(new KeyExtent(tac.getExtent()));
+  public TabletId getTablet() {
+    return new TabletIdImpl(new KeyExtent(tac.getExtent()));
   }
 
   @Override

http://git-wip-us.apache.org/repos/asf/accumulo/blob/ac08cc4d/core/src/main/java/org/apache/accumulo/core/client/impl/ActiveScanImpl.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/ActiveScanImpl.java b/core/src/main/java/org/apache/accumulo/core/client/impl/ActiveScanImpl.java
index 602a422..429f8cd 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/ActiveScanImpl.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/ActiveScanImpl.java
@@ -26,9 +26,9 @@ import org.apache.accumulo.core.client.admin.ActiveScan;
 import org.apache.accumulo.core.client.admin.ScanState;
 import org.apache.accumulo.core.client.admin.ScanType;
 import org.apache.accumulo.core.data.Column;
-import org.apache.accumulo.core.data.TabletID;
+import org.apache.accumulo.core.data.TabletId;
 import org.apache.accumulo.core.data.impl.KeyExtent;
-import org.apache.accumulo.core.data.impl.TabletIDImpl;
+import org.apache.accumulo.core.data.impl.TabletIdImpl;
 import org.apache.accumulo.core.data.thrift.IterInfo;
 import org.apache.accumulo.core.data.thrift.TColumn;
 import org.apache.accumulo.core.security.Authorizations;
@@ -125,8 +125,8 @@ public class ActiveScanImpl extends ActiveScan {
   }
 
   @Override
-  public TabletID getTablet() {
-    return new TabletIDImpl(extent);
+  public TabletId getTablet() {
+    return new TabletIdImpl(extent);
   }
 
   @Override

http://git-wip-us.apache.org/repos/asf/accumulo/blob/ac08cc4d/core/src/main/java/org/apache/accumulo/core/client/impl/TabletServerBatchWriter.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/impl/TabletServerBatchWriter.java b/core/src/main/java/org/apache/accumulo/core/client/impl/TabletServerBatchWriter.java
index 6a4d348..f14116a 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/impl/TabletServerBatchWriter.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/impl/TabletServerBatchWriter.java
@@ -50,9 +50,9 @@ import org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException;
 import org.apache.accumulo.core.constraints.Violations;
 import org.apache.accumulo.core.data.ConstraintViolationSummary;
 import org.apache.accumulo.core.data.Mutation;
-import org.apache.accumulo.core.data.TabletID;
+import org.apache.accumulo.core.data.TabletId;
 import org.apache.accumulo.core.data.impl.KeyExtent;
-import org.apache.accumulo.core.data.impl.TabletIDImpl;
+import org.apache.accumulo.core.data.impl.TabletIdImpl;
 import org.apache.accumulo.core.data.thrift.TMutation;
 import org.apache.accumulo.core.data.thrift.UpdateErrors;
 import org.apache.accumulo.core.master.state.tables.TableState;
@@ -536,7 +536,7 @@ public class TabletServerBatchWriter {
   private void checkForFailures() throws MutationsRejectedException {
     if (somethingFailed) {
       List<ConstraintViolationSummary> cvsList = violations.asList();
-      HashMap<TabletID,Set<org.apache.accumulo.core.client.security.SecurityErrorCode>> af = new HashMap<TabletID,Set<org.apache.accumulo.core.client.security.SecurityErrorCode>>();
+      HashMap<TabletId,Set<org.apache.accumulo.core.client.security.SecurityErrorCode>> af = new HashMap<TabletId,Set<org.apache.accumulo.core.client.security.SecurityErrorCode>>();
       for (Entry<KeyExtent,Set<SecurityErrorCode>> entry : authorizationFailures.entrySet()) {
         HashSet<org.apache.accumulo.core.client.security.SecurityErrorCode> codes = new HashSet<org.apache.accumulo.core.client.security.SecurityErrorCode>();
 
@@ -544,7 +544,7 @@ public class TabletServerBatchWriter {
           codes.add(org.apache.accumulo.core.client.security.SecurityErrorCode.valueOf(sce.name()));
         }
 
-        af.put(new TabletIDImpl(entry.getKey()), codes);
+        af.put(new TabletIdImpl(entry.getKey()), codes);
       }
 
       throw new MutationsRejectedException(context.getInstance(), cvsList, af, serverSideErrors, unknownErrors, lastUnknownError);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/ac08cc4d/core/src/main/java/org/apache/accumulo/core/client/mapred/AccumuloOutputFormat.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/mapred/AccumuloOutputFormat.java b/core/src/main/java/org/apache/accumulo/core/client/mapred/AccumuloOutputFormat.java
index 62ca05c..88ed184 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/mapred/AccumuloOutputFormat.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/mapred/AccumuloOutputFormat.java
@@ -49,7 +49,7 @@ import org.apache.accumulo.core.client.security.tokens.KerberosToken;
 import org.apache.accumulo.core.client.security.tokens.PasswordToken;
 import org.apache.accumulo.core.data.ColumnUpdate;
 import org.apache.accumulo.core.data.Mutation;
-import org.apache.accumulo.core.data.TabletID;
+import org.apache.accumulo.core.data.TabletId;
 import org.apache.accumulo.core.security.ColumnVisibility;
 import org.apache.hadoop.fs.FileSystem;
 import org.apache.hadoop.io.Text;
@@ -544,7 +544,7 @@ public class AccumuloOutputFormat implements OutputFormat<Text,Mutation> {
       } catch (MutationsRejectedException e) {
         if (e.getSecurityErrorCodes().size() >= 0) {
           HashMap<String,Set<SecurityErrorCode>> tables = new HashMap<String,Set<SecurityErrorCode>>();
-          for (Entry<TabletID,Set<SecurityErrorCode>> ke : e.getSecurityErrorCodes().entrySet()) {
+          for (Entry<TabletId,Set<SecurityErrorCode>> ke : e.getSecurityErrorCodes().entrySet()) {
             Set<SecurityErrorCode> secCodes = tables.get(ke.getKey().getTableId().toString());
             if (secCodes == null) {
               secCodes = new HashSet<SecurityErrorCode>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/ac08cc4d/core/src/main/java/org/apache/accumulo/core/client/mapreduce/AccumuloOutputFormat.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/AccumuloOutputFormat.java b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/AccumuloOutputFormat.java
index 76fe523..4cb46a3 100644
--- a/core/src/main/java/org/apache/accumulo/core/client/mapreduce/AccumuloOutputFormat.java
+++ b/core/src/main/java/org/apache/accumulo/core/client/mapreduce/AccumuloOutputFormat.java
@@ -49,7 +49,7 @@ import org.apache.accumulo.core.client.security.tokens.KerberosToken;
 import org.apache.accumulo.core.client.security.tokens.PasswordToken;
 import org.apache.accumulo.core.data.ColumnUpdate;
 import org.apache.accumulo.core.data.Mutation;
-import org.apache.accumulo.core.data.TabletID;
+import org.apache.accumulo.core.data.TabletId;
 import org.apache.accumulo.core.security.ColumnVisibility;
 import org.apache.hadoop.io.Text;
 import org.apache.hadoop.mapreduce.Job;
@@ -544,7 +544,7 @@ public class AccumuloOutputFormat extends OutputFormat<Text,Mutation> {
       } catch (MutationsRejectedException e) {
         if (e.getSecurityErrorCodes().size() >= 0) {
           HashMap<String,Set<SecurityErrorCode>> tables = new HashMap<String,Set<SecurityErrorCode>>();
-          for (Entry<TabletID,Set<SecurityErrorCode>> ke : e.getSecurityErrorCodes().entrySet()) {
+          for (Entry<TabletId,Set<SecurityErrorCode>> ke : e.getSecurityErrorCodes().entrySet()) {
             Set<SecurityErrorCode> secCodes = tables.get(ke.getKey().getTableId().toString());
             if (secCodes == null) {
               secCodes = new HashSet<SecurityErrorCode>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/ac08cc4d/core/src/main/java/org/apache/accumulo/core/data/KeyExtent.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/KeyExtent.java b/core/src/main/java/org/apache/accumulo/core/data/KeyExtent.java
index f730cf6..e9f3b65 100644
--- a/core/src/main/java/org/apache/accumulo/core/data/KeyExtent.java
+++ b/core/src/main/java/org/apache/accumulo/core/data/KeyExtent.java
@@ -37,7 +37,7 @@ import org.apache.hadoop.io.WritableComparable;
 /**
  * keeps track of information needed to identify a tablet
  *
- * @deprecated since 1.7.0 use {@link TabletID}
+ * @deprecated since 1.7.0 use {@link TabletId}
  */
 @Deprecated
 public class KeyExtent implements WritableComparable<KeyExtent> {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/ac08cc4d/core/src/main/java/org/apache/accumulo/core/data/TabletID.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/TabletID.java b/core/src/main/java/org/apache/accumulo/core/data/TabletID.java
deleted file mode 100644
index bfcb742..0000000
--- a/core/src/main/java/org/apache/accumulo/core/data/TabletID.java
+++ /dev/null
@@ -1,29 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.accumulo.core.data;
-
-import org.apache.hadoop.io.Text;
-
-/**
- * @since 1.7.0
- */
-public interface TabletID extends Comparable<TabletID> {
-  public Text getTableId();
-  public Text getEndRow();
-  public Text getPrevEndRow();
-}

http://git-wip-us.apache.org/repos/asf/accumulo/blob/ac08cc4d/core/src/main/java/org/apache/accumulo/core/data/TabletId.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/TabletId.java b/core/src/main/java/org/apache/accumulo/core/data/TabletId.java
new file mode 100644
index 0000000..2dfba47
--- /dev/null
+++ b/core/src/main/java/org/apache/accumulo/core/data/TabletId.java
@@ -0,0 +1,31 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.accumulo.core.data;
+
+import org.apache.hadoop.io.Text;
+
+/**
+ * A TabletId provides the information needed to uniquely identify a tablet.
+ *
+ * @since 1.7.0
+ */
+public interface TabletId extends Comparable<TabletId> {
+  public Text getTableId();
+  public Text getEndRow();
+  public Text getPrevEndRow();
+}

http://git-wip-us.apache.org/repos/asf/accumulo/blob/ac08cc4d/core/src/main/java/org/apache/accumulo/core/data/impl/TabletIDImpl.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/impl/TabletIDImpl.java b/core/src/main/java/org/apache/accumulo/core/data/impl/TabletIDImpl.java
deleted file mode 100644
index dd90e0d..0000000
--- a/core/src/main/java/org/apache/accumulo/core/data/impl/TabletIDImpl.java
+++ /dev/null
@@ -1,100 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.accumulo.core.data.impl;
-
-import org.apache.accumulo.core.data.TabletID;
-import org.apache.hadoop.io.Text;
-
-import com.google.common.base.Function;
-
-public class TabletIDImpl implements TabletID {
-
-  private KeyExtent ke;
-
-  @SuppressWarnings("deprecation")
-  public static final Function<org.apache.accumulo.core.data.KeyExtent,TabletID> KE_2_TID_OLD = new Function<org.apache.accumulo.core.data.KeyExtent,TabletID>() {
-    @Override
-    public TabletID apply(org.apache.accumulo.core.data.KeyExtent input) {
-      //the following if null check is to appease findbugs... grumble grumble spent a good part of my morning looking into this
-      // http://sourceforge.net/p/findbugs/bugs/1139/
-      // https://code.google.com/p/guava-libraries/issues/detail?id=920
-      if(input == null)
-        return null;
-      return new TabletIDImpl(input);
-    }
-  };
-
-  @SuppressWarnings("deprecation")
-  public static final Function<TabletID, org.apache.accumulo.core.data.KeyExtent> TID_2_KE_OLD = new Function<TabletID, org.apache.accumulo.core.data.KeyExtent>() {
-    @Override
-    public org.apache.accumulo.core.data.KeyExtent apply(TabletID input) {
-      if(input == null)
-        return null;
-      return new org.apache.accumulo.core.data.KeyExtent(input.getTableId(), input.getEndRow(), input.getPrevEndRow());
-    }
-
-  };
-
-  @Deprecated
-  public TabletIDImpl(org.apache.accumulo.core.data.KeyExtent ke) {
-    this.ke = new KeyExtent(ke.getTableId(), ke.getEndRow(), ke.getPrevEndRow());
-  }
-
-  public TabletIDImpl(KeyExtent ke) {
-    this.ke = ke;
-  }
-
-  @Override
-  public int compareTo(TabletID o) {
-    return ke.compareTo(((TabletIDImpl) o).ke);
-  }
-
-  @Override
-  public Text getTableId() {
-    return ke.getTableId();
-  }
-
-  @Override
-  public Text getEndRow() {
-    return ke.getEndRow();
-  }
-
-  @Override
-  public Text getPrevEndRow() {
-    return ke.getPrevEndRow();
-  }
-
-  @Override
-  public int hashCode() {
-    return ke.hashCode();
-  }
-
-  @Override
-  public boolean equals(Object o) {
-    if (o instanceof TabletIDImpl) {
-      return ke.equals(((TabletIDImpl) o).ke);
-    }
-
-    return false;
-  }
-
-  @Override
-  public String toString(){
-    return ke.toString();
-  }
-}

http://git-wip-us.apache.org/repos/asf/accumulo/blob/ac08cc4d/core/src/main/java/org/apache/accumulo/core/data/impl/TabletIdImpl.java
----------------------------------------------------------------------
diff --git a/core/src/main/java/org/apache/accumulo/core/data/impl/TabletIdImpl.java b/core/src/main/java/org/apache/accumulo/core/data/impl/TabletIdImpl.java
new file mode 100644
index 0000000..395dd22
--- /dev/null
+++ b/core/src/main/java/org/apache/accumulo/core/data/impl/TabletIdImpl.java
@@ -0,0 +1,100 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.accumulo.core.data.impl;
+
+import org.apache.accumulo.core.data.TabletId;
+import org.apache.hadoop.io.Text;
+
+import com.google.common.base.Function;
+
+public class TabletIdImpl implements TabletId {
+
+  private KeyExtent ke;
+
+  @SuppressWarnings("deprecation")
+  public static final Function<org.apache.accumulo.core.data.KeyExtent,TabletId> KE_2_TID_OLD = new Function<org.apache.accumulo.core.data.KeyExtent,TabletId>() {
+    @Override
+    public TabletId apply(org.apache.accumulo.core.data.KeyExtent input) {
+      //the following if null check is to appease findbugs... grumble grumble spent a good part of my morning looking into this
+      // http://sourceforge.net/p/findbugs/bugs/1139/
+      // https://code.google.com/p/guava-libraries/issues/detail?id=920
+      if(input == null)
+        return null;
+      return new TabletIdImpl(input);
+    }
+  };
+
+  @SuppressWarnings("deprecation")
+  public static final Function<TabletId, org.apache.accumulo.core.data.KeyExtent> TID_2_KE_OLD = new Function<TabletId, org.apache.accumulo.core.data.KeyExtent>() {
+    @Override
+    public org.apache.accumulo.core.data.KeyExtent apply(TabletId input) {
+      if(input == null)
+        return null;
+      return new org.apache.accumulo.core.data.KeyExtent(input.getTableId(), input.getEndRow(), input.getPrevEndRow());
+    }
+
+  };
+
+  @Deprecated
+  public TabletIdImpl(org.apache.accumulo.core.data.KeyExtent ke) {
+    this.ke = new KeyExtent(ke.getTableId(), ke.getEndRow(), ke.getPrevEndRow());
+  }
+
+  public TabletIdImpl(KeyExtent ke) {
+    this.ke = ke;
+  }
+
+  @Override
+  public int compareTo(TabletId o) {
+    return ke.compareTo(((TabletIdImpl) o).ke);
+  }
+
+  @Override
+  public Text getTableId() {
+    return ke.getTableId();
+  }
+
+  @Override
+  public Text getEndRow() {
+    return ke.getEndRow();
+  }
+
+  @Override
+  public Text getPrevEndRow() {
+    return ke.getPrevEndRow();
+  }
+
+  @Override
+  public int hashCode() {
+    return ke.hashCode();
+  }
+
+  @Override
+  public boolean equals(Object o) {
+    if (o instanceof TabletIdImpl) {
+      return ke.equals(((TabletIdImpl) o).ke);
+    }
+
+    return false;
+  }
+
+  @Override
+  public String toString(){
+    return ke.toString();
+  }
+}

http://git-wip-us.apache.org/repos/asf/accumulo/blob/ac08cc4d/examples/simple/src/main/java/org/apache/accumulo/examples/simple/client/RandomBatchWriter.java
----------------------------------------------------------------------
diff --git a/examples/simple/src/main/java/org/apache/accumulo/examples/simple/client/RandomBatchWriter.java b/examples/simple/src/main/java/org/apache/accumulo/examples/simple/client/RandomBatchWriter.java
index c1fb875..05a737f 100644
--- a/examples/simple/src/main/java/org/apache/accumulo/examples/simple/client/RandomBatchWriter.java
+++ b/examples/simple/src/main/java/org/apache/accumulo/examples/simple/client/RandomBatchWriter.java
@@ -32,7 +32,7 @@ import org.apache.accumulo.core.client.MutationsRejectedException;
 import org.apache.accumulo.core.client.TableNotFoundException;
 import org.apache.accumulo.core.client.security.SecurityErrorCode;
 import org.apache.accumulo.core.data.Mutation;
-import org.apache.accumulo.core.data.TabletID;
+import org.apache.accumulo.core.data.TabletId;
 import org.apache.accumulo.core.data.Value;
 import org.apache.accumulo.core.security.ColumnVisibility;
 import org.apache.hadoop.io.Text;
@@ -157,7 +157,7 @@ public class RandomBatchWriter {
     } catch (MutationsRejectedException e) {
       if (e.getSecurityErrorCodes().size() > 0) {
         HashMap<String,Set<SecurityErrorCode>> tables = new HashMap<String,Set<SecurityErrorCode>>();
-        for (Entry<TabletID,Set<SecurityErrorCode>> ke : e.getSecurityErrorCodes().entrySet()) {
+        for (Entry<TabletId,Set<SecurityErrorCode>> ke : e.getSecurityErrorCodes().entrySet()) {
           Set<SecurityErrorCode> secCodes = tables.get(ke.getKey().getTableId().toString());
           if (secCodes == null) {
             secCodes = new HashSet<SecurityErrorCode>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/ac08cc4d/proxy/src/main/java/org/apache/accumulo/proxy/ProxyServer.java
----------------------------------------------------------------------
diff --git a/proxy/src/main/java/org/apache/accumulo/proxy/ProxyServer.java b/proxy/src/main/java/org/apache/accumulo/proxy/ProxyServer.java
index 382b47e..5a05431 100644
--- a/proxy/src/main/java/org/apache/accumulo/proxy/ProxyServer.java
+++ b/proxy/src/main/java/org/apache/accumulo/proxy/ProxyServer.java
@@ -72,7 +72,7 @@ import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.data.Mutation;
 import org.apache.accumulo.core.data.PartialKey;
 import org.apache.accumulo.core.data.Range;
-import org.apache.accumulo.core.data.TabletID;
+import org.apache.accumulo.core.data.TabletId;
 import org.apache.accumulo.core.data.Value;
 import org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope;
 import org.apache.accumulo.core.security.Authorizations;
@@ -724,7 +724,7 @@ public class ProxyServer implements AccumuloProxy.Iface {
         pscan.idleTime = scan.getIdleTime();
         pscan.type = ScanType.valueOf(scan.getType().toString());
         pscan.state = ScanState.valueOf(scan.getState().toString());
-        TabletID e = scan.getTablet();
+        TabletId e = scan.getTablet();
         pscan.extent = new org.apache.accumulo.proxy.thrift.KeyExtent(e.getTableId().toString(), TextUtil.getByteBuffer(e.getEndRow()),
             TextUtil.getByteBuffer(e.getPrevEndRow()));
         pscan.columns = new ArrayList<org.apache.accumulo.proxy.thrift.Column>();
@@ -776,7 +776,7 @@ public class ProxyServer implements AccumuloProxy.Iface {
         pcomp.age = comp.getAge();
         pcomp.entriesRead = comp.getEntriesRead();
         pcomp.entriesWritten = comp.getEntriesWritten();
-        TabletID e = comp.getTablet();
+        TabletId e = comp.getTablet();
         pcomp.extent = new org.apache.accumulo.proxy.thrift.KeyExtent(e.getTableId().toString(), TextUtil.getByteBuffer(e.getEndRow()),
             TextUtil.getByteBuffer(e.getPrevEndRow()));
         pcomp.inputFiles = new ArrayList<String>();

http://git-wip-us.apache.org/repos/asf/accumulo/blob/ac08cc4d/shell/src/main/java/org/apache/accumulo/shell/commands/InsertCommand.java
----------------------------------------------------------------------
diff --git a/shell/src/main/java/org/apache/accumulo/shell/commands/InsertCommand.java b/shell/src/main/java/org/apache/accumulo/shell/commands/InsertCommand.java
index 71e3855..af5f810 100644
--- a/shell/src/main/java/org/apache/accumulo/shell/commands/InsertCommand.java
+++ b/shell/src/main/java/org/apache/accumulo/shell/commands/InsertCommand.java
@@ -33,7 +33,7 @@ import org.apache.accumulo.core.client.security.SecurityErrorCode;
 import org.apache.accumulo.core.conf.AccumuloConfiguration;
 import org.apache.accumulo.core.data.ConstraintViolationSummary;
 import org.apache.accumulo.core.data.Mutation;
-import org.apache.accumulo.core.data.TabletID;
+import org.apache.accumulo.core.data.TabletId;
 import org.apache.accumulo.core.data.Value;
 import org.apache.accumulo.core.security.ColumnVisibility;
 import org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException;
@@ -110,7 +110,7 @@ public class InsertCommand extends Command {
       if (e.getSecurityErrorCodes().isEmpty() == false) {
         lines.add("\tAuthorization Failures:");
       }
-      for (Entry<TabletID,Set<SecurityErrorCode>> entry : e.getSecurityErrorCodes().entrySet()) {
+      for (Entry<TabletId,Set<SecurityErrorCode>> entry : e.getSecurityErrorCodes().entrySet()) {
         lines.add("\t\t" + entry);
       }
       if (e.getConstraintViolationSummaries().isEmpty() == false) {

http://git-wip-us.apache.org/repos/asf/accumulo/blob/ac08cc4d/test/src/main/java/org/apache/accumulo/test/TestIngest.java
----------------------------------------------------------------------
diff --git a/test/src/main/java/org/apache/accumulo/test/TestIngest.java b/test/src/main/java/org/apache/accumulo/test/TestIngest.java
index a18f610..33e03ef 100644
--- a/test/src/main/java/org/apache/accumulo/test/TestIngest.java
+++ b/test/src/main/java/org/apache/accumulo/test/TestIngest.java
@@ -39,7 +39,7 @@ import org.apache.accumulo.core.conf.AccumuloConfiguration;
 import org.apache.accumulo.core.data.ConstraintViolationSummary;
 import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.data.Mutation;
-import org.apache.accumulo.core.data.TabletID;
+import org.apache.accumulo.core.data.TabletId;
 import org.apache.accumulo.core.data.Value;
 import org.apache.accumulo.core.file.FileOperations;
 import org.apache.accumulo.core.file.FileSKVWriter;
@@ -313,7 +313,7 @@ public class TestIngest {
         bw.close();
       } catch (MutationsRejectedException e) {
         if (e.getSecurityErrorCodes().size() > 0) {
-          for (Entry<TabletID,Set<SecurityErrorCode>> entry : e.getSecurityErrorCodes().entrySet()) {
+          for (Entry<TabletId,Set<SecurityErrorCode>> entry : e.getSecurityErrorCodes().entrySet()) {
             System.err.println("ERROR : Not authorized to write to : " + entry.getKey() + " due to " + entry.getValue());
           }
         }