You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@accumulo.apache.org by el...@apache.org on 2015/07/02 19:28:40 UTC

[2/2] accumulo git commit: ACCUMULO-3927 Commit checkstyle changes

ACCUMULO-3927 Commit checkstyle changes


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

Branch: refs/heads/master
Commit: eb1ba18607e1afd3d15a7ba86f968fe47e53d7b8
Parents: bb031b3
Author: Josh Elser <el...@apache.org>
Authored: Thu Jul 2 13:27:27 2015 -0400
Committer: Josh Elser <el...@apache.org>
Committed: Thu Jul 2 13:27:27 2015 -0400

----------------------------------------------------------------------
 .../org/apache/accumulo/tserver/tablet/SplitInfo.java    |  6 +++---
 .../java/org/apache/accumulo/tserver/tablet/Tablet.java  | 11 ++++++-----
 .../main/java/org/apache/accumulo/test/ManySplitIT.java  |  5 ++---
 3 files changed, 11 insertions(+), 11 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/eb1ba186/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/SplitInfo.java
----------------------------------------------------------------------
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/SplitInfo.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/SplitInfo.java
index 64b6a11..3cae52c 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/SplitInfo.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/SplitInfo.java
@@ -41,10 +41,10 @@ final public class SplitInfo {
   private final long initFlushID;
   private final long initCompactID;
   private final TServerInstance lastLocation;
-  private final Map<Long, ? extends Collection<FileRef>> bulkImported;
+  private final Map<Long,? extends Collection<FileRef>> bulkImported;
 
   SplitInfo(String d, SortedMap<FileRef,DataFileValue> dfv, String time, long initFlushID, long initCompactID, TServerInstance lastLocation,
-      Map<Long, ? extends Collection<FileRef>> bulkImported) {
+      Map<Long,? extends Collection<FileRef>> bulkImported) {
     this.dir = d;
     this.datafiles = dfv;
     this.time = time;
@@ -78,7 +78,7 @@ final public class SplitInfo {
     return lastLocation;
   }
 
-  public Map<Long, ? extends Collection<FileRef>> getBulkImported() {
+  public Map<Long,? extends Collection<FileRef>> getBulkImported() {
     return bulkImported;
   }
 

http://git-wip-us.apache.org/repos/asf/accumulo/blob/eb1ba186/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/Tablet.java
----------------------------------------------------------------------
diff --git a/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/Tablet.java b/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/Tablet.java
index c0fb918..a40c95d 100644
--- a/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/Tablet.java
+++ b/server/tserver/src/main/java/org/apache/accumulo/tserver/tablet/Tablet.java
@@ -322,7 +322,7 @@ public class Tablet implements TabletCommitter {
   }
 
   private Tablet(TabletServer tabletServer, Text location, KeyExtent extent, TabletResourceManager trm, SortedMap<FileRef,DataFileValue> datafiles,
-      String time, long initFlushID, long initCompactID, TServerInstance lastLocation, Map<Long, ? extends Collection<FileRef>> bulkImported) throws IOException {
+      String time, long initFlushID, long initCompactID, TServerInstance lastLocation, Map<Long,? extends Collection<FileRef>> bulkImported) throws IOException {
     this(tabletServer, extent, location, trm, NO_LOG_ENTRIES, datafiles, time, lastLocation, new HashSet<FileRef>(), initFlushID, initCompactID, bulkImported);
   }
 
@@ -445,7 +445,7 @@ public class Tablet implements TabletCommitter {
     return null;
   }
 
-  private static Map<Long, List<FileRef>> lookupBulkImported(SortedMap<Key,Value> tabletsKeyValues, VolumeManager fs) {
+  private static Map<Long,List<FileRef>> lookupBulkImported(SortedMap<Key,Value> tabletsKeyValues, VolumeManager fs) {
     Map<Long,List<FileRef>> result = new HashMap<>();
     for (Entry<Key,Value> entry : tabletsKeyValues.entrySet()) {
       if (entry.getKey().getColumnFamily().compareTo(BulkFileColumnFamily.NAME) == 0) {
@@ -473,7 +473,8 @@ public class Tablet implements TabletCommitter {
    */
   private Tablet(final TabletServer tabletServer, final KeyExtent extent, final Text location, final TabletResourceManager trm,
       final List<LogEntry> rawLogEntries, final SortedMap<FileRef,DataFileValue> rawDatafiles, String time, final TServerInstance lastLocation,
-      final Set<FileRef> scanFiles, final long initFlushID, final long initCompactID, final Map<Long, ? extends Collection<FileRef>> bulkImported) throws IOException {
+      final Set<FileRef> scanFiles, final long initFlushID, final long initCompactID, final Map<Long,? extends Collection<FileRef>> bulkImported)
+      throws IOException {
 
     TableConfiguration tblConf = tabletServer.getTableConfiguration(extent);
     if (null == tblConf) {
@@ -2297,8 +2298,8 @@ public class Tablet implements TabletCommitter {
       String time = tabletTime.getMetadataValue();
 
       MetadataTableUtil.splitTablet(high, extent.getPrevEndRow(), splitRatio, getTabletServer(), getTabletServer().getLock());
-      MasterMetadataUtil.addNewTablet(getTabletServer(), low, lowDirectory, getTabletServer().getTabletSession(), lowDatafileSizes, getBulkIngestedFiles(), time,
-          lastFlushID, lastCompactID, getTabletServer().getLock());
+      MasterMetadataUtil.addNewTablet(getTabletServer(), low, lowDirectory, getTabletServer().getTabletSession(), lowDatafileSizes, getBulkIngestedFiles(),
+          time, lastFlushID, lastCompactID, getTabletServer().getLock());
       MetadataTableUtil.finishSplit(high, highDatafileSizes, highDatafilesToRemove, getTabletServer(), getTabletServer().getLock());
 
       log.log(TLevel.TABLET_HIST, extent + " split " + low + " " + high);

http://git-wip-us.apache.org/repos/asf/accumulo/blob/eb1ba186/test/src/main/java/org/apache/accumulo/test/ManySplitIT.java
----------------------------------------------------------------------
diff --git a/test/src/main/java/org/apache/accumulo/test/ManySplitIT.java b/test/src/main/java/org/apache/accumulo/test/ManySplitIT.java
index dc61f53..5676831 100644
--- a/test/src/main/java/org/apache/accumulo/test/ManySplitIT.java
+++ b/test/src/main/java/org/apache/accumulo/test/ManySplitIT.java
@@ -37,7 +37,6 @@ import org.apache.hadoop.conf.Configuration;
 import org.apache.hadoop.io.Text;
 import org.junit.Test;
 
-
 public class ManySplitIT extends ConfigurableMacBase {
 
   final int SPLITS = 10_000;
@@ -53,7 +52,7 @@ public class ManySplitIT extends ConfigurableMacBase {
     tableOperations.create(tableName);
     SortedSet<Text> splits = new TreeSet<Text>();
     for (byte b : "123456789abcde".getBytes(UTF_8)) {
-      splits.add(new Text(new byte[]{'1', ';', b}));
+      splits.add(new Text(new byte[] {'1', ';', b}));
     }
     tableOperations.addSplits(MetadataTable.NAME, splits);
     splits.clear();
@@ -69,7 +68,7 @@ public class ManySplitIT extends ConfigurableMacBase {
         while (!stop.get()) {
           UtilWaitThread.sleep(1000);
           try {
-            log.info("splits: " + tableOperations.listSplits(tableName).size() );
+            log.info("splits: " + tableOperations.listSplits(tableName).size());
           } catch (TableNotFoundException | AccumuloException | AccumuloSecurityException e) {
             // TODO Auto-generated catch block
             e.printStackTrace();