You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@accumulo.apache.org by vi...@apache.org on 2011/10/27 17:25:17 UTC

svn commit: r1189806 [11/46] - in /incubator/accumulo: branches/1.3/contrib/ branches/1.3/src/core/src/main/java/org/apache/accumulo/core/client/ branches/1.3/src/core/src/main/java/org/apache/accumulo/core/client/admin/ branches/1.3/src/core/src/main/...

Modified: incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/IntersectingIterator.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/IntersectingIterator.java?rev=1189806&r1=1189805&r2=1189806&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/IntersectingIterator.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/IntersectingIterator.java Thu Oct 27 15:24:51 2011
@@ -353,7 +353,8 @@ public class IntersectingIterator implem
   }
   
   public static String stringTopKey(SortedKeyValueIterator<Key,Value> iter) {
-    if (iter.hasTop()) return iter.getTopKey().toString();
+    if (iter.hasTop())
+      return iter.getTopKey().toString();
     return "";
   }
   
@@ -372,8 +373,10 @@ public class IntersectingIterator implem
   public static String encodeBooleans(boolean[] flags) {
     byte[] bytes = new byte[flags.length];
     for (int i = 0; i < flags.length; i++) {
-      if (flags[i]) bytes[i] = 1;
-      else bytes[i] = 0;
+      if (flags[i])
+        bytes[i] = 1;
+      else
+        bytes[i] = 0;
     }
     return new String(Base64.encodeBase64(bytes));
   }
@@ -389,13 +392,16 @@ public class IntersectingIterator implem
   
   public static boolean[] decodeBooleans(String flags) {
     // return null of there were no flags
-    if (flags == null) return null;
+    if (flags == null)
+      return null;
     
     byte[] bytes = Base64.decodeBase64(flags.getBytes());
     boolean[] bFlags = new boolean[bytes.length];
     for (int i = 0; i < bytes.length; i++) {
-      if (bytes[i] == 1) bFlags[i] = true;
-      else bFlags[i] = false;
+      if (bytes[i] == 1)
+        bFlags[i] = true;
+      else
+        bFlags[i] = false;
     }
     return bFlags;
   }

Modified: incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/IteratorUtil.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/IteratorUtil.java?rev=1189806&r1=1189805&r2=1189806&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/IteratorUtil.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/IteratorUtil.java Thu Oct 27 15:24:51 2011
@@ -84,7 +84,8 @@ public class IteratorUtil {
     int max = 0;
     
     for (IterInfo iterInfo : iters) {
-      if (iterInfo.priority > max) max = iterInfo.priority;
+      if (iterInfo.priority > max)
+        max = iterInfo.priority;
     }
     
     return max;
@@ -185,9 +186,12 @@ public class IteratorUtil {
         Map<String,String> options = allOptions.get(iterInfo.iterName);
         Map<String,String> userOptions = ssio.get(iterInfo.iterName);
         
-        if (options == null && userOptions == null) options = Collections.emptyMap();
-        else if (options == null && userOptions != null) options = userOptions;
-        else if (options != null && userOptions != null) options.putAll(userOptions);
+        if (options == null && userOptions == null)
+          options = Collections.emptyMap();
+        else if (options == null && userOptions != null)
+          options = userOptions;
+        else if (options != null && userOptions != null)
+          options.putAll(userOptions);
         
         skvi.init(prev, options, env);
         prev = skvi;

Modified: incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/LargeRowFilter.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/LargeRowFilter.java?rev=1189806&r1=1189805&r2=1189806&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/LargeRowFilter.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/LargeRowFilter.java Thu Oct 27 15:24:51 2011
@@ -219,7 +219,8 @@ public class LargeRowFilter implements S
       while (currentPosition < keys.size() && range.beforeStartKey(keys.get(currentPosition)))
         currentPosition++;
       
-      if (currentPosition == keys.size()) readNextRow();
+      if (currentPosition == keys.size())
+        readNextRow();
       
     } else {
       source.seek(range, columnFamilies, inclusive);

Modified: incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/MultiIterator.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/MultiIterator.java?rev=1189806&r1=1189805&r2=1189806&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/MultiIterator.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/MultiIterator.java Thu Oct 27 15:24:51 2011
@@ -95,7 +95,8 @@ public class MultiIterator extends HeapI
     
     if (fence != null) {
       range = fence.clip(range, true);
-      if (range == null) return;
+      if (range == null)
+        return;
     }
     
     for (SortedKeyValueIterator<Key,Value> skvi : iters) {

Modified: incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/OrIterator.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/OrIterator.java?rev=1189806&r1=1189805&r2=1189806&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/OrIterator.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/OrIterator.java Thu Oct 27 15:24:51 2011
@@ -90,13 +90,15 @@ public class OrIterator implements Sorte
   @Override
   final public void next() throws IOException {
     
-    if (currentTerm == null) return;
+    if (currentTerm == null)
+      return;
     
     // Advance currentTerm
     currentTerm.iter.next();
     
     // See if currentTerm is still valid, remove if not
-    if (!(currentTerm.iter.hasTop()) || ((currentTerm.term != null) && (currentTerm.term.compareTo(currentTerm.iter.getTopKey().getColumnFamily()) != 0))) currentTerm = null;
+    if (!(currentTerm.iter.hasTop()) || ((currentTerm.term != null) && (currentTerm.term.compareTo(currentTerm.iter.getTopKey().getColumnFamily()) != 0)))
+      currentTerm = null;
     
     // optimization.
     // if size == 0, currentTerm is the only item left,
@@ -104,7 +106,8 @@ public class OrIterator implements Sorte
     // In either case, we don't need to use the PriorityQueue
     if (sorted.size() > 0) {
       // sort the term back in
-      if (currentTerm != null) sorted.add(currentTerm);
+      if (currentTerm != null)
+        sorted.add(currentTerm);
       // and get the current top item out.
       currentTerm = sorted.poll();
     }
@@ -124,17 +127,19 @@ public class OrIterator implements Sorte
     // and we don't have a priority queue of size 0 or 1.
     if (sources.size() == 1) {
       
-      if (currentTerm == null) currentTerm = sources.get(0);
+      if (currentTerm == null)
+        currentTerm = sources.get(0);
       Range newRange = null;
       
       if (range != null) {
-        if ((range.getStartKey() == null) || (range.getStartKey().getRow() == null)) newRange = range;
+        if ((range.getStartKey() == null) || (range.getStartKey().getRow() == null))
+          newRange = range;
         else {
           Key newKey = null;
-          if (range.getStartKey().getColumnQualifier() == null) newKey = new Key(range.getStartKey().getRow(), (currentTerm.term == null) ? nullText
-              : currentTerm.term);
-          else newKey = new Key(range.getStartKey().getRow(), (currentTerm.term == null) ? nullText : currentTerm.term, range.getStartKey()
-              .getColumnQualifier());
+          if (range.getStartKey().getColumnQualifier() == null)
+            newKey = new Key(range.getStartKey().getRow(), (currentTerm.term == null) ? nullText : currentTerm.term);
+          else
+            newKey = new Key(range.getStartKey().getRow(), (currentTerm.term == null) ? nullText : currentTerm.term, range.getStartKey().getColumnQualifier());
           newRange = new Range((newKey == null) ? nullKey : newKey, true, range.getEndKey(), false);
         }
       }
@@ -145,7 +150,8 @@ public class OrIterator implements Sorte
       // 1) NOT an iterator
       // 2) we have seeked into the next term (ie: seek man, get man001)
       // then ignore it as a valid source
-      if (!(currentTerm.iter.hasTop()) || ((currentTerm.term != null) && (currentTerm.term.compareTo(currentTerm.iter.getTopKey().getColumnFamily()) != 0))) currentTerm = null;
+      if (!(currentTerm.iter.hasTop()) || ((currentTerm.term != null) && (currentTerm.term.compareTo(currentTerm.iter.getTopKey().getColumnFamily()) != 0)))
+        currentTerm = null;
       
       // Otherwise, source is valid.
       return;
@@ -162,7 +168,8 @@ public class OrIterator implements Sorte
       for (TermSource TS : sources) {
         TS.iter.seek(range, columnFamilies, inclusive);
         
-        if ((TS.iter.hasTop()) && ((TS.term != null) || (TS.term.compareTo(TS.iter.getTopKey().getColumnFamily()) == 0))) sorted.add(TS);
+        if ((TS.iter.hasTop()) && ((TS.term != null) || (TS.term.compareTo(TS.iter.getTopKey().getColumnFamily()) == 0)))
+          sorted.add(TS);
       }
       currentTerm = sorted.poll();
       return;
@@ -177,11 +184,14 @@ public class OrIterator implements Sorte
       Range newRange = null;
       
       if (range != null) {
-        if ((range.getStartKey() == null) || (range.getStartKey().getRow() == null)) newRange = range;
+        if ((range.getStartKey() == null) || (range.getStartKey().getRow() == null))
+          newRange = range;
         else {
           Key newKey = null;
-          if (range.getStartKey().getColumnQualifier() == null) newKey = new Key(range.getStartKey().getRow(), (TS.term == null) ? nullText : TS.term);
-          else newKey = new Key(range.getStartKey().getRow(), (TS.term == null) ? nullText : TS.term, range.getStartKey().getColumnQualifier());
+          if (range.getStartKey().getColumnQualifier() == null)
+            newKey = new Key(range.getStartKey().getRow(), (TS.term == null) ? nullText : TS.term);
+          else
+            newKey = new Key(range.getStartKey().getRow(), (TS.term == null) ? nullText : TS.term, range.getStartKey().getColumnQualifier());
           newRange = new Range((newKey == null) ? nullKey : newKey, true, range.getEndKey(), false);
         }
       }
@@ -193,7 +203,8 @@ public class OrIterator implements Sorte
       // 1) NOT an iterator
       // 2) we have seeked into the next term (ie: seek man, get man001)
       // then ignore it as a valid source
-      if (!(TS.iter.hasTop()) || ((TS.term != null) && (TS.term.compareTo(TS.iter.getTopKey().getColumnFamily()) != 0))) iter.remove();
+      if (!(TS.iter.hasTop()) || ((TS.term != null) && (TS.term.compareTo(TS.iter.getTopKey().getColumnFamily()) != 0)))
+        iter.remove();
       
       // Otherwise, source is valid. Add it to the sources.
       sorted.add(TS);

Modified: incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/RowDeletingIterator.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/RowDeletingIterator.java?rev=1189806&r1=1189805&r2=1189806&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/RowDeletingIterator.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/RowDeletingIterator.java Thu Oct 27 15:24:51 2011
@@ -129,7 +129,8 @@ public class RowDeletingIterator impleme
         currentRowDeleted = true;
         deleteTS = source.getTopKey().getTimestamp();
         
-        if (propogateDeletes) break;
+        if (propogateDeletes)
+          break;
       } else {
         break;
       }

Modified: incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/ScanCache.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/ScanCache.java?rev=1189806&r1=1189805&r2=1189806&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/ScanCache.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/ScanCache.java Thu Oct 27 15:24:51 2011
@@ -154,7 +154,8 @@ public class ScanCache implements Sorted
       // assert(outOfEntries == topCacheEntry.getValue().exitPoint);
       if (topCacheEntry.getValue().exitPoint == true) {
         // log.debug("Adding " + topKey + " to noLongerExitPoints");
-        if (currentScanOversize == false) noLongerExitPoints.add(topKey);
+        if (currentScanOversize == false)
+          noLongerExitPoints.add(topKey);
         // get the next cache entry
         if (cacheIterator.hasNext() == false) {
           topCacheEntry = null;
@@ -216,8 +217,10 @@ public class ScanCache implements Sorted
     
     // grab the first entry from the cache that is greater than or equal to the given key k
     cacheIterator = cacheEntries.tailMap(k).entrySet().iterator();
-    if (cacheIterator.hasNext()) topCacheEntry = cacheIterator.next();
-    else topCacheEntry = null;
+    if (cacheIterator.hasNext())
+      topCacheEntry = cacheIterator.next();
+    else
+      topCacheEntry = null;
     // if we're skipping the given key, we should be past it at this point
     
     // if there is something in the cache then we should try to use it
@@ -409,7 +412,8 @@ public class ScanCache implements Sorted
       // update the time of the entry point
       if (latestEntryPoint != null) {
         // only add the true entry points to the timesOfEntryPoints map
-        if (cacheEntries.get(latestEntryPoint).entryPoint) timesOfEntryPoints.put(currentScanTime, latestEntryPoint);
+        if (cacheEntries.get(latestEntryPoint).entryPoint)
+          timesOfEntryPoints.put(currentScanTime, latestEntryPoint);
       }
       
       // free some space if necessary
@@ -444,7 +448,8 @@ public class ScanCache implements Sorted
       Entry<Long,Key> firstTimeEntryPoint = entryTimeIter.next();
       entryTimeIter.remove();
       makeRoomSecondTimeEntryPoint = null;
-      if (entryTimeIter.hasNext()) makeRoomSecondTimeEntryPoint = entryTimeIter.next();
+      if (entryTimeIter.hasNext())
+        makeRoomSecondTimeEntryPoint = entryTimeIter.next();
       
       makeRoomCacheIter = cacheEntries.tailMap(firstTimeEntryPoint.getValue()).entrySet().iterator();
     }
@@ -454,7 +459,8 @@ public class ScanCache implements Sorted
   // prefer to remove very small segments
   // prefer to remove portions from one end of a large segment
   private void makeRoom() {
-    if (currentSize <= maxSize) return;
+    if (currentSize <= maxSize)
+      return;
     
     // only remove from the beginning of a contiguous section to preserve contiguous sections
     // support removing the tail of a contiguous section as well to prevent bad cases with backwards sequential reads

Modified: incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/SequenceFileIterator.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/SequenceFileIterator.java?rev=1189806&r1=1189805&r2=1189806&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/SequenceFileIterator.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/SequenceFileIterator.java Thu Oct 27 15:24:51 2011
@@ -55,7 +55,8 @@ public class SequenceFileIterator implem
     
     top_key = new Key();
     
-    if (readValue) top_value = new Value();
+    if (readValue)
+      top_value = new Value();
     
     next();
   }
@@ -74,8 +75,10 @@ public class SequenceFileIterator implem
   
   public void next() throws IOException {
     boolean valid;
-    if (readValue) valid = reader.next(top_key, top_value);
-    else valid = reader.next(top_key);
+    if (readValue)
+      valid = reader.next(top_key, top_value);
+    else
+      valid = reader.next(top_key);
     
     if (!valid) {
       top_key = null;

Modified: incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/SortedMapIterator.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/SortedMapIterator.java?rev=1189806&r1=1189805&r2=1189806&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/SortedMapIterator.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/SortedMapIterator.java Thu Oct 27 15:24:51 2011
@@ -53,8 +53,10 @@ public class SortedMapIterator implement
     this.map = map;
     iter = map.entrySet().iterator();
     this.range = new Range();
-    if (iter.hasNext()) entry = iter.next();
-    else entry = null;
+    if (iter.hasNext())
+      entry = iter.next();
+    else
+      entry = null;
     
     this.interruptFlag = interruptFlag;
   }
@@ -81,16 +83,19 @@ public class SortedMapIterator implement
   @Override
   public void next() throws IOException {
     
-    if (entry == null) throw new IllegalStateException();
+    if (entry == null)
+      throw new IllegalStateException();
     
-    if (interruptFlag != null && interruptCheckCount++ % 100 == 0 && interruptFlag.get()) throw new IterationInterruptedException();
+    if (interruptFlag != null && interruptCheckCount++ % 100 == 0 && interruptFlag.get())
+      throw new IterationInterruptedException();
     
     if (iter.hasNext()) {
       entry = iter.next();
       if (range.afterEndKey((Key) entry.getKey())) {
         entry = null;
       }
-    } else entry = null;
+    } else
+      entry = null;
     
   }
   
@@ -101,7 +106,8 @@ public class SortedMapIterator implement
       throw new IllegalArgumentException("I do not know how to filter column families");
     }
     
-    if (interruptFlag != null && interruptFlag.get()) throw new IterationInterruptedException();
+    if (interruptFlag != null && interruptFlag.get())
+      throw new IterationInterruptedException();
     
     this.range = range;
     
@@ -116,7 +122,8 @@ public class SortedMapIterator implement
       if (range.afterEndKey(entry.getKey())) {
         entry = null;
       }
-    } else entry = null;
+    } else
+      entry = null;
     
     while (hasTop() && range.beforeStartKey(getTopKey())) {
       next();

Modified: incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/SourceSwitchingIterator.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/SourceSwitchingIterator.java?rev=1189806&r1=1189805&r2=1189806&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/SourceSwitchingIterator.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/SourceSwitchingIterator.java Thu Oct 27 15:24:51 2011
@@ -109,8 +109,11 @@ public class SourceSwitchingIterator imp
     // circuit the call to switchSource
     boolean seekNeeded = (!onlySwitchAfterRow && switchSource()) || initialSeek;
     
-    if (seekNeeded) if (initialSeek) iter.seek(range, columnFamilies, inclusive);
-    else iter.seek(new Range(key, false, range.getEndKey(), range.isEndKeyInclusive()), columnFamilies, inclusive);
+    if (seekNeeded)
+      if (initialSeek)
+        iter.seek(range, columnFamilies, inclusive);
+      else
+        iter.seek(new Range(key, false, range.getEndKey(), range.isEndKeyInclusive()), columnFamilies, inclusive);
     else {
       iter.next();
       if (onlySwitchAfterRow && iter.hasTop() && !source.isCurrent() && !key.getRowData().equals(iter.getTopKey().getRowData())) {
@@ -135,7 +138,8 @@ public class SourceSwitchingIterator imp
     while (!source.isCurrent()) {
       source = source.getNewDataSource();
       iter = source.iterator();
-      if (iflag != null) ((InterruptibleIterator) iter).setInterruptFlag(iflag);
+      if (iflag != null)
+        ((InterruptibleIterator) iter).setInterruptFlag(iflag);
       
       return true;
     }
@@ -151,14 +155,16 @@ public class SourceSwitchingIterator imp
     
     if (iter == null) {
       iter = source.iterator();
-      if (iflag != null) ((InterruptibleIterator) iter).setInterruptFlag(iflag);
+      if (iflag != null)
+        ((InterruptibleIterator) iter).setInterruptFlag(iflag);
     }
     
     readNext(true);
   }
   
   private synchronized void _switchNow() throws IOException {
-    if (onlySwitchAfterRow) throw new IllegalStateException("Can only switch on row boundries");
+    if (onlySwitchAfterRow)
+      throw new IllegalStateException("Can only switch on row boundries");
     
     if (switchSource()) {
       if (key != null) {
@@ -176,10 +182,12 @@ public class SourceSwitchingIterator imp
   
   @Override
   public synchronized void setInterruptFlag(AtomicBoolean flag) {
-    if (copies.size() != 1) throw new IllegalStateException("setInterruptFlag() called after deep copies made " + copies.size());
+    if (copies.size() != 1)
+      throw new IllegalStateException("setInterruptFlag() called after deep copies made " + copies.size());
     
     this.iflag = flag;
-    if (iter != null) ((InterruptibleIterator) iter).setInterruptFlag(flag);
+    if (iter != null)
+      ((InterruptibleIterator) iter).setInterruptFlag(flag);
     
   }
   

Modified: incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/VersioningIterator.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/VersioningIterator.java?rev=1189806&r1=1189805&r2=1189806&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/VersioningIterator.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/VersioningIterator.java Thu Oct 27 15:24:51 2011
@@ -52,7 +52,8 @@ public class VersioningIterator extends 
   public VersioningIterator() {}
   
   public VersioningIterator(SortedKeyValueIterator<Key,Value> iterator, int maxVersions) {
-    if (maxVersions < 1) throw new IllegalArgumentException("maxVersions for versioning iterator must be >= 1");
+    if (maxVersions < 1)
+      throw new IllegalArgumentException("maxVersions for versioning iterator must be >= 1");
     this.setSource(iterator);
     this.maxVersions = maxVersions;
     lazyReset = true;
@@ -60,7 +61,8 @@ public class VersioningIterator extends 
   
   @Override
   public void next() throws IOException {
-    if (lazyReset) resetVersionCount();
+    if (lazyReset)
+      resetVersionCount();
     
     if (numVersions >= maxVersions) {
       skipRowColumn();
@@ -80,7 +82,8 @@ public class VersioningIterator extends 
   
   @Override
   public boolean hasTop() {
-    if (lazyReset) resetVersionCount();
+    if (lazyReset)
+      resetVersionCount();
     return super.hasTop();
   }
   
@@ -107,7 +110,8 @@ public class VersioningIterator extends 
   }
   
   private void resetVersionCount() {
-    if (getSource().hasTop()) currentKey.set(getSource().getTopKey());
+    if (getSource().hasTop())
+      currentKey.set(getSource().getTopKey());
     numVersions = 1;
     lazyReset = false;
   }
@@ -127,10 +131,13 @@ public class VersioningIterator extends 
     this.numVersions = 0;
     
     String maxVerString = options.get("maxVersions");
-    if (maxVerString != null) this.maxVersions = Integer.parseInt(maxVerString);
-    else this.maxVersions = 1;
+    if (maxVerString != null)
+      this.maxVersions = Integer.parseInt(maxVerString);
+    else
+      this.maxVersions = 1;
     
-    if (maxVersions < 1) throw new IllegalArgumentException("maxVersions for versioning iterator must be >= 1");
+    if (maxVersions < 1)
+      throw new IllegalArgumentException("maxVersions for versioning iterator must be >= 1");
     
     lazyReset = true;
   }
@@ -144,7 +151,8 @@ public class VersioningIterator extends 
   @Override
   public boolean validateOptions(Map<String,String> options) {
     int i = Integer.parseInt(options.get("maxVersions"));
-    if (i < 1) throw new IllegalArgumentException("maxVersions for versioning iterator must be >= 1");
+    if (i < 1)
+      throw new IllegalArgumentException("maxVersions for versioning iterator must be >= 1");
     return true;
   }
 }

Modified: incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/WholeRowIterator.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/WholeRowIterator.java?rev=1189806&r1=1189805&r2=1189806&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/WholeRowIterator.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/WholeRowIterator.java Thu Oct 27 15:24:51 2011
@@ -148,10 +148,12 @@ public class WholeRowIterator implements
   List<Value> values = new ArrayList<Value>();
   
   private void prepKeys() throws IOException {
-    if (topKey != null) return;
+    if (topKey != null)
+      return;
     Text currentRow;
     do {
-      if (sourceIter.hasTop() == false) return;
+      if (sourceIter.hasTop() == false)
+        return;
       currentRow = new Text(sourceIter.getTopKey().getRow());
       keys.clear();
       values.clear();
@@ -183,7 +185,8 @@ public class WholeRowIterator implements
   
   @Override
   public SortedKeyValueIterator<Key,Value> deepCopy(IteratorEnvironment env) {
-    if (sourceIter != null) return new WholeRowIterator(sourceIter.deepCopy(env));
+    if (sourceIter != null)
+      return new WholeRowIterator(sourceIter.deepCopy(env));
     return new WholeRowIterator();
   }
   
@@ -226,7 +229,8 @@ public class WholeRowIterator implements
       // assuming that we are seeking using a key previously returned by this iterator
       // therefore go to the next row
       Key followingRowKey = sk.followingKey(PartialKey.ROW);
-      if (range.getEndKey() != null && followingRowKey.compareTo(range.getEndKey()) > 0) return;
+      if (range.getEndKey() != null && followingRowKey.compareTo(range.getEndKey()) > 0)
+        return;
       
       range = new Range(sk.followingKey(PartialKey.ROW), true, range.getEndKey(), range.isEndKeyInclusive());
     }

Modified: incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/LongSummation.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/LongSummation.java?rev=1189806&r1=1189805&r2=1189806&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/LongSummation.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/LongSummation.java Thu Oct 27 15:24:51 2011
@@ -46,8 +46,8 @@ public class LongSummation implements Ag
   }
   
   public static long bytesToLong(byte[] b, int offset) throws IOException {
-    if (b.length < offset + 8) throw new IOException("trying to convert to long, but byte array isn't long enough, wanted " + (offset + 8) + " found "
-        + b.length);
+    if (b.length < offset + 8)
+      throw new IOException("trying to convert to long, but byte array isn't long enough, wanted " + (offset + 8) + " found " + b.length);
     return (((long) b[offset + 0] << 56) + ((long) (b[offset + 1] & 255) << 48) + ((long) (b[offset + 2] & 255) << 40) + ((long) (b[offset + 3] & 255) << 32)
         + ((long) (b[offset + 4] & 255) << 24) + ((b[offset + 5] & 255) << 16) + ((b[offset + 6] & 255) << 8) + ((b[offset + 7] & 255) << 0));
   }

Modified: incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/NumSummation.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/NumSummation.java?rev=1189806&r1=1189805&r2=1189806&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/NumSummation.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/aggregation/NumSummation.java Thu Oct 27 15:24:51 2011
@@ -66,9 +66,11 @@ public class NumSummation implements Agg
     long bSign = Long.signum(b);
     if ((aSign != 0) && (bSign != 0) && (aSign == bSign)) {
       if (aSign > 0) {
-        if (Long.MAX_VALUE - a < b) return Long.MAX_VALUE;
+        if (Long.MAX_VALUE - a < b)
+          return Long.MAX_VALUE;
       } else {
-        if (Long.MIN_VALUE - a > b) return Long.MIN_VALUE;
+        if (Long.MIN_VALUE - a > b)
+          return Long.MIN_VALUE;
       }
     }
     return a + b;

Modified: incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/conf/ColumnToClassMapping.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/conf/ColumnToClassMapping.java?rev=1189806&r1=1189805&r2=1189806&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/conf/ColumnToClassMapping.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/conf/ColumnToClassMapping.java Thu Oct 27 15:24:51 2011
@@ -67,12 +67,14 @@ public class ColumnToClassMapping<K> {
     }
     
     public boolean equals(Object o) {
-      if (o instanceof ColFamHashKey) return equals((ColFamHashKey) o);
+      if (o instanceof ColFamHashKey)
+        return equals((ColFamHashKey) o);
       return false;
     }
     
     public boolean equals(ColFamHashKey ohk) {
-      if (columnFamily == null) return key.compareColumnFamily(ohk.columnFamily) == 0;
+      if (columnFamily == null)
+        return key.compareColumnFamily(ohk.columnFamily) == 0;
       return ohk.key.compareColumnFamily(columnFamily) == 0;
     }
   }
@@ -106,12 +108,14 @@ public class ColumnToClassMapping<K> {
     }
     
     public boolean equals(Object o) {
-      if (o instanceof ColHashKey) return equals((ColHashKey) o);
+      if (o instanceof ColHashKey)
+        return equals((ColHashKey) o);
       return false;
     }
     
     public boolean equals(ColHashKey ohk) {
-      if (columnFamily == null) return key.compareColumnFamily(ohk.columnFamily) == 0 && key.compareColumnQualifier(ohk.columnQualifier) == 0;
+      if (columnFamily == null)
+        return key.compareColumnFamily(ohk.columnFamily) == 0 && key.compareColumnQualifier(ohk.columnQualifier) == 0;
       return ohk.key.compareColumnFamily(columnFamily) == 0 && ohk.key.compareColumnQualifier(columnQualifier) == 0;
     }
   }

Modified: incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/filter/AgeOffFilter.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/filter/AgeOffFilter.java?rev=1189806&r1=1189805&r2=1189806&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/filter/AgeOffFilter.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/filter/AgeOffFilter.java Thu Oct 27 15:24:51 2011
@@ -29,23 +29,28 @@ public class AgeOffFilter implements Fil
   
   @Override
   public boolean accept(Key k, Value v) {
-    if (currentTime - k.getTimestamp() > threshold) return false;
+    if (currentTime - k.getTimestamp() > threshold)
+      return false;
     return true;
   }
   
   @Override
   public void init(Map<String,String> options) {
     threshold = -1;
-    if (options == null) throw new IllegalArgumentException("ttl must be set for AgeOffFilter");
+    if (options == null)
+      throw new IllegalArgumentException("ttl must be set for AgeOffFilter");
     
     String ttl = options.get("ttl");
-    if (ttl == null) throw new IllegalArgumentException("ttl must be set for AgeOffFilter");
+    if (ttl == null)
+      throw new IllegalArgumentException("ttl must be set for AgeOffFilter");
     
     threshold = Long.parseLong(ttl);
     
     String time = options.get("currentTime");
-    if (time != null) currentTime = Long.parseLong(time);
-    else currentTime = System.currentTimeMillis();
+    if (time != null)
+      currentTime = Long.parseLong(time);
+    else
+      currentTime = System.currentTimeMillis();
     
     // add sanity checks for threshold and currentTime?
   }

Modified: incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/filter/ColumnAgeOffFilter.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/filter/ColumnAgeOffFilter.java?rev=1189806&r1=1189805&r2=1189806&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/filter/ColumnAgeOffFilter.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/filter/ColumnAgeOffFilter.java Thu Oct 27 15:24:51 2011
@@ -54,8 +54,10 @@ public class ColumnAgeOffFilter implemen
   @Override
   public boolean accept(Key k, Value v) {
     Long threshold = ttls.getObject(k);
-    if (threshold == null) return true;
-    if (currentTime - k.getTimestamp() > threshold) return false;
+    if (threshold == null)
+      return true;
+    if (currentTime - k.getTimestamp() > threshold)
+      return false;
     return true;
   }
   

Modified: incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/filter/ColumnQualifierFilter.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/filter/ColumnQualifierFilter.java?rev=1189806&r1=1189805&r2=1189806&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/filter/ColumnQualifierFilter.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/filter/ColumnQualifierFilter.java Thu Oct 27 15:24:51 2011
@@ -37,9 +37,11 @@ public class ColumnQualifierFilter imple
   }
   
   public boolean accept(Key key, Value v) {
-    if (!scanColumns) return true;
+    if (!scanColumns)
+      return true;
     
-    if (columnFamilies.contains(key.getColumnFamilyData())) return true;
+    if (columnFamilies.contains(key.getColumnFamilyData()))
+      return true;
     
     HashSet<ByteSequence> cfset = columnsQualifiers.get(key.getColumnQualifierData());
     // ensure the columm qualifier goes with a paired column family,

Modified: incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/filter/RegExFilter.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/filter/RegExFilter.java?rev=1189806&r1=1189805&r2=1189806&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/filter/RegExFilter.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/filter/RegExFilter.java Thu Oct 27 15:24:51 2011
@@ -66,8 +66,9 @@ public class RegExFilter implements Filt
   
   @Override
   public boolean accept(Key key, Value value) {
-    if (orFields) return matches(rowMatcher, key.getRowData()) || matches(colfMatcher, key.getColumnFamilyData())
-        || matches(colqMatcher, key.getColumnQualifierData()) || matches(valueMatcher, value.get(), 0, value.get().length);
+    if (orFields)
+      return matches(rowMatcher, key.getRowData()) || matches(colfMatcher, key.getColumnFamilyData()) || matches(colqMatcher, key.getColumnQualifierData())
+          || matches(valueMatcher, value.get(), 0, value.get().length);
     return matches(rowMatcher, key.getRowData()) && matches(colfMatcher, key.getColumnFamilyData()) && matches(colqMatcher, key.getColumnQualifierData())
         && matches(valueMatcher, value.get(), 0, value.get().length);
   }
@@ -119,13 +120,17 @@ public class RegExFilter implements Filt
   
   @Override
   public boolean validateOptions(Map<String,String> options) {
-    if (options.containsKey(ROW_REGEX)) Pattern.compile(options.get(ROW_REGEX)).matcher("");
+    if (options.containsKey(ROW_REGEX))
+      Pattern.compile(options.get(ROW_REGEX)).matcher("");
     
-    if (options.containsKey(COLF_REGEX)) Pattern.compile(options.get(COLF_REGEX)).matcher("");
+    if (options.containsKey(COLF_REGEX))
+      Pattern.compile(options.get(COLF_REGEX)).matcher("");
     
-    if (options.containsKey(COLQ_REGEX)) Pattern.compile(options.get(COLQ_REGEX)).matcher("");
+    if (options.containsKey(COLQ_REGEX))
+      Pattern.compile(options.get(COLQ_REGEX)).matcher("");
     
-    if (options.containsKey(VALUE_REGEX)) Pattern.compile(options.get(VALUE_REGEX)).matcher("");
+    if (options.containsKey(VALUE_REGEX))
+      Pattern.compile(options.get(VALUE_REGEX)).matcher("");
     
     return true;
   }

Modified: incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/filter/VisibilityFilter.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/filter/VisibilityFilter.java?rev=1189806&r1=1189805&r2=1189806&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/filter/VisibilityFilter.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/iterators/filter/VisibilityFilter.java Thu Oct 27 15:24:51 2011
@@ -46,11 +46,14 @@ public class VisibilityFilter implements
   public boolean accept(Key k, Value v) {
     Text testVis = k.getColumnVisibility(tmpVis);
     
-    if (testVis.getLength() == 0 && defaultVisibility.getLength() == 0) return true;
-    else if (testVis.getLength() == 0) testVis = defaultVisibility;
+    if (testVis.getLength() == 0 && defaultVisibility.getLength() == 0)
+      return true;
+    else if (testVis.getLength() == 0)
+      testVis = defaultVisibility;
     
     Boolean b = (Boolean) cache.get(testVis);
-    if (b != null) return b;
+    if (b != null)
+      return b;
     
     try {
       Boolean bb = ve.evaluate(new ColumnVisibility(testVis));

Modified: incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/master/thrift/Compacting.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/master/thrift/Compacting.java?rev=1189806&r1=1189805&r2=1189806&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/master/thrift/Compacting.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/master/thrift/Compacting.java Thu Oct 27 15:24:51 2011
@@ -5,40 +5,37 @@
  */
 package org.apache.accumulo.core.master.thrift;
 
-
-
 import org.apache.thrift.*;
 import org.apache.thrift.meta_data.*;
 import org.apache.thrift.protocol.*;
 
 @SuppressWarnings("serial")
-public class Compacting implements TBase<Compacting, Compacting._Fields>, java.io.Serializable, Cloneable {
+public class Compacting implements TBase<Compacting,Compacting._Fields>, java.io.Serializable, Cloneable {
   private static final TStruct STRUCT_DESC = new TStruct("Compacting");
-
-  private static final TField RUNNING_FIELD_DESC = new TField("running", TType.I32, (short)1);
-  private static final TField QUEUED_FIELD_DESC = new TField("queued", TType.I32, (short)2);
-
+  
+  private static final TField RUNNING_FIELD_DESC = new TField("running", TType.I32, (short) 1);
+  private static final TField QUEUED_FIELD_DESC = new TField("queued", TType.I32, (short) 2);
+  
   public int running;
   public int queued;
-
+  
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
   public enum _Fields implements TFieldIdEnum {
-    RUNNING((short)1, "running"),
-    QUEUED((short)2, "queued");
-
-    private static final java.util.Map<String, _Fields> byName = new java.util.HashMap<String, _Fields>();
-
+    RUNNING((short) 1, "running"), QUEUED((short) 2, "queued");
+    
+    private static final java.util.Map<String,_Fields> byName = new java.util.HashMap<String,_Fields>();
+    
     static {
       for (_Fields field : java.util.EnumSet.allOf(_Fields.class)) {
         byName.put(field.getFieldName(), field);
       }
     }
-
+    
     /**
      * Find the _Fields constant that matches fieldId, or null if its not found.
      */
     public static _Fields findByThriftId(int fieldId) {
-      switch(fieldId) {
+      switch (fieldId) {
         case 1: // RUNNING
           return RUNNING;
         case 2: // QUEUED
@@ -47,71 +44,65 @@ public class Compacting implements TBase
           return null;
       }
     }
-
+    
     /**
-     * Find the _Fields constant that matches fieldId, throwing an exception
-     * if it is not found.
+     * Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
      */
     public static _Fields findByThriftIdOrThrow(int fieldId) {
       _Fields fields = findByThriftId(fieldId);
-      if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!");
+      if (fields == null)
+        throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!");
       return fields;
     }
-
+    
     /**
      * Find the _Fields constant that matches name, or null if its not found.
      */
     public static _Fields findByName(String name) {
       return byName.get(name);
     }
-
+    
     private final short _thriftId;
     private final String _fieldName;
-
+    
     _Fields(short thriftId, String fieldName) {
       _thriftId = thriftId;
       _fieldName = fieldName;
     }
-
+    
     public short getThriftFieldId() {
       return _thriftId;
     }
-
+    
     public String getFieldName() {
       return _fieldName;
     }
   }
-
+  
   // isset id assignments
   private static final int __RUNNING_ISSET_ID = 0;
   private static final int __QUEUED_ISSET_ID = 1;
   private java.util.BitSet __isset_bit_vector = new java.util.BitSet(2);
-
-  public static final java.util.Map<_Fields, FieldMetaData> metaDataMap;
+  
+  public static final java.util.Map<_Fields,FieldMetaData> metaDataMap;
   static {
-    java.util.Map<_Fields, FieldMetaData> tmpMap = new java.util.EnumMap<_Fields, FieldMetaData>(_Fields.class);
-    tmpMap.put(_Fields.RUNNING, new FieldMetaData("running", TFieldRequirementType.DEFAULT, 
-        new FieldValueMetaData(TType.I32)));
-    tmpMap.put(_Fields.QUEUED, new FieldMetaData("queued", TFieldRequirementType.DEFAULT, 
-        new FieldValueMetaData(TType.I32)));
+    java.util.Map<_Fields,FieldMetaData> tmpMap = new java.util.EnumMap<_Fields,FieldMetaData>(_Fields.class);
+    tmpMap.put(_Fields.RUNNING, new FieldMetaData("running", TFieldRequirementType.DEFAULT, new FieldValueMetaData(TType.I32)));
+    tmpMap.put(_Fields.QUEUED, new FieldMetaData("queued", TFieldRequirementType.DEFAULT, new FieldValueMetaData(TType.I32)));
     metaDataMap = java.util.Collections.unmodifiableMap(tmpMap);
     FieldMetaData.addStructMetaDataMap(Compacting.class, metaDataMap);
   }
-
-  public Compacting() {
-  }
-
-  public Compacting(
-    int running,
-    int queued)
-  {
+  
+  public Compacting() {}
+  
+  public Compacting(int running, int queued) {
     this();
     this.running = running;
     setRunningIsSet(true);
     this.queued = queued;
     setQueuedIsSet(true);
   }
-
+  
   /**
    * Performs a deep copy on <i>other</i>.
    */
@@ -121,131 +112,131 @@ public class Compacting implements TBase
     this.running = other.running;
     this.queued = other.queued;
   }
-
+  
   public Compacting deepCopy() {
     return new Compacting(this);
   }
-
+  
   @Deprecated
   public Compacting clone() {
     return new Compacting(this);
   }
-
+  
   public int getRunning() {
     return this.running;
   }
-
+  
   public Compacting setRunning(int running) {
     this.running = running;
     setRunningIsSet(true);
     return this;
   }
-
+  
   public void unsetRunning() {
     __isset_bit_vector.clear(__RUNNING_ISSET_ID);
   }
-
+  
   /** Returns true if field running is set (has been asigned a value) and false otherwise */
   public boolean isSetRunning() {
     return __isset_bit_vector.get(__RUNNING_ISSET_ID);
   }
-
+  
   public void setRunningIsSet(boolean value) {
     __isset_bit_vector.set(__RUNNING_ISSET_ID, value);
   }
-
+  
   public int getQueued() {
     return this.queued;
   }
-
+  
   public Compacting setQueued(int queued) {
     this.queued = queued;
     setQueuedIsSet(true);
     return this;
   }
-
+  
   public void unsetQueued() {
     __isset_bit_vector.clear(__QUEUED_ISSET_ID);
   }
-
+  
   /** Returns true if field queued is set (has been asigned a value) and false otherwise */
   public boolean isSetQueued() {
     return __isset_bit_vector.get(__QUEUED_ISSET_ID);
   }
-
+  
   public void setQueuedIsSet(boolean value) {
     __isset_bit_vector.set(__QUEUED_ISSET_ID, value);
   }
-
+  
   public void setFieldValue(_Fields field, Object value) {
     switch (field) {
-    case RUNNING:
-      if (value == null) {
-        unsetRunning();
-      } else {
-        setRunning((Integer)value);
-      }
-      break;
-
-    case QUEUED:
-      if (value == null) {
-        unsetQueued();
-      } else {
-        setQueued((Integer)value);
-      }
-      break;
-
+      case RUNNING:
+        if (value == null) {
+          unsetRunning();
+        } else {
+          setRunning((Integer) value);
+        }
+        break;
+      
+      case QUEUED:
+        if (value == null) {
+          unsetQueued();
+        } else {
+          setQueued((Integer) value);
+        }
+        break;
+    
     }
   }
-
+  
   public void setFieldValue(int fieldID, Object value) {
     setFieldValue(_Fields.findByThriftIdOrThrow(fieldID), value);
   }
-
+  
   public Object getFieldValue(_Fields field) {
     switch (field) {
-    case RUNNING:
-      return new Integer(getRunning());
-
-    case QUEUED:
-      return new Integer(getQueued());
-
+      case RUNNING:
+        return new Integer(getRunning());
+        
+      case QUEUED:
+        return new Integer(getQueued());
+        
     }
     throw new IllegalStateException();
   }
-
+  
   public Object getFieldValue(int fieldId) {
     return getFieldValue(_Fields.findByThriftIdOrThrow(fieldId));
   }
-
+  
   /** Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise */
   public boolean isSet(_Fields field) {
     switch (field) {
-    case RUNNING:
-      return isSetRunning();
-    case QUEUED:
-      return isSetQueued();
+      case RUNNING:
+        return isSetRunning();
+      case QUEUED:
+        return isSetQueued();
     }
     throw new IllegalStateException();
   }
-
+  
   public boolean isSet(int fieldID) {
     return isSet(_Fields.findByThriftIdOrThrow(fieldID));
   }
-
+  
   @Override
   public boolean equals(Object that) {
     if (that == null)
       return false;
     if (that instanceof Compacting)
-      return this.equals((Compacting)that);
+      return this.equals((Compacting) that);
     return false;
   }
-
+  
   public boolean equals(Compacting that) {
     if (that == null)
       return false;
-
+    
     boolean this_present_running = true;
     boolean that_present_running = true;
     if (this_present_running || that_present_running) {
@@ -254,7 +245,7 @@ public class Compacting implements TBase
       if (this.running != that.running)
         return false;
     }
-
+    
     boolean this_present_queued = true;
     boolean that_present_queued = true;
     if (this_present_queued || that_present_queued) {
@@ -263,28 +254,29 @@ public class Compacting implements TBase
       if (this.queued != that.queued)
         return false;
     }
-
+    
     return true;
   }
-
+  
   @Override
   public int hashCode() {
     return 0;
   }
-
+  
   public int compareTo(Compacting other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
-
+    
     int lastComparison = 0;
-    Compacting typedOther = (Compacting)other;
-
+    Compacting typedOther = (Compacting) other;
+    
     lastComparison = Boolean.valueOf(isSetRunning()).compareTo(typedOther.isSetRunning());
     if (lastComparison != 0) {
       return lastComparison;
     }
-    if (isSetRunning()) {      lastComparison = TBaseHelper.compareTo(this.running, typedOther.running);
+    if (isSetRunning()) {
+      lastComparison = TBaseHelper.compareTo(this.running, typedOther.running);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -293,21 +285,21 @@ public class Compacting implements TBase
     if (lastComparison != 0) {
       return lastComparison;
     }
-    if (isSetQueued()) {      lastComparison = TBaseHelper.compareTo(this.queued, typedOther.queued);
+    if (isSetQueued()) {
+      lastComparison = TBaseHelper.compareTo(this.queued, typedOther.queued);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
     return 0;
   }
-
+  
   public void read(TProtocol iprot) throws TException {
     TField field;
     iprot.readStructBegin();
-    while (true)
-    {
+    while (true) {
       field = iprot.readFieldBegin();
-      if (field.type == TType.STOP) { 
+      if (field.type == TType.STOP) {
         break;
       }
       switch (field.id) {
@@ -315,7 +307,7 @@ public class Compacting implements TBase
           if (field.type == TType.I32) {
             this.running = iprot.readI32();
             setRunningIsSet(true);
-          } else { 
+          } else {
             TProtocolUtil.skip(iprot, field.type);
           }
           break;
@@ -323,7 +315,7 @@ public class Compacting implements TBase
           if (field.type == TType.I32) {
             this.queued = iprot.readI32();
             setQueuedIsSet(true);
-          } else { 
+          } else {
             TProtocolUtil.skip(iprot, field.type);
           }
           break;
@@ -333,14 +325,14 @@ public class Compacting implements TBase
       iprot.readFieldEnd();
     }
     iprot.readStructEnd();
-
+    
     // check for required fields of primitive type, which can't be checked in the validate method
     validate();
   }
-
+  
   public void write(TProtocol oprot) throws TException {
     validate();
-
+    
     oprot.writeStructBegin(STRUCT_DESC);
     oprot.writeFieldBegin(RUNNING_FIELD_DESC);
     oprot.writeI32(this.running);
@@ -351,7 +343,7 @@ public class Compacting implements TBase
     oprot.writeFieldStop();
     oprot.writeStructEnd();
   }
-
+  
   @Override
   public String toString() {
     StringBuilder sb = new StringBuilder("Compacting(");
@@ -363,10 +355,9 @@ public class Compacting implements TBase
     sb.append(")");
     return sb.toString();
   }
-
+  
   public void validate() throws TException {
     // check for required fields
   }
-
+  
 }
-

Modified: incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/master/thrift/LoggerStatus.java
URL: http://svn.apache.org/viewvc/incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/master/thrift/LoggerStatus.java?rev=1189806&r1=1189805&r2=1189806&view=diff
==============================================================================
--- incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/master/thrift/LoggerStatus.java (original)
+++ incubator/accumulo/branches/1.3/src/core/src/main/java/org/apache/accumulo/core/master/thrift/LoggerStatus.java Thu Oct 27 15:24:51 2011
@@ -5,99 +5,93 @@
  */
 package org.apache.accumulo.core.master.thrift;
 
-
-
 import org.apache.thrift.*;
 import org.apache.thrift.meta_data.*;
 import org.apache.thrift.protocol.*;
 
 @SuppressWarnings("serial")
-public class LoggerStatus implements TBase<LoggerStatus, LoggerStatus._Fields>, java.io.Serializable, Cloneable {
+public class LoggerStatus implements TBase<LoggerStatus,LoggerStatus._Fields>, java.io.Serializable, Cloneable {
   private static final TStruct STRUCT_DESC = new TStruct("LoggerStatus");
-
-  private static final TField LOGGER_FIELD_DESC = new TField("logger", TType.STRING, (short)1);
-
+  
+  private static final TField LOGGER_FIELD_DESC = new TField("logger", TType.STRING, (short) 1);
+  
   public String logger;
-
+  
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
   public enum _Fields implements TFieldIdEnum {
-    LOGGER((short)1, "logger");
-
-    private static final java.util.Map<String, _Fields> byName = new java.util.HashMap<String, _Fields>();
-
+    LOGGER((short) 1, "logger");
+    
+    private static final java.util.Map<String,_Fields> byName = new java.util.HashMap<String,_Fields>();
+    
     static {
       for (_Fields field : java.util.EnumSet.allOf(_Fields.class)) {
         byName.put(field.getFieldName(), field);
       }
     }
-
+    
     /**
      * Find the _Fields constant that matches fieldId, or null if its not found.
      */
     public static _Fields findByThriftId(int fieldId) {
-      switch(fieldId) {
+      switch (fieldId) {
         case 1: // LOGGER
           return LOGGER;
         default:
           return null;
       }
     }
-
+    
     /**
-     * Find the _Fields constant that matches fieldId, throwing an exception
-     * if it is not found.
+     * Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
      */
     public static _Fields findByThriftIdOrThrow(int fieldId) {
       _Fields fields = findByThriftId(fieldId);
-      if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!");
+      if (fields == null)
+        throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!");
       return fields;
     }
-
+    
     /**
      * Find the _Fields constant that matches name, or null if its not found.
      */
     public static _Fields findByName(String name) {
       return byName.get(name);
     }
-
+    
     private final short _thriftId;
     private final String _fieldName;
-
+    
     _Fields(short thriftId, String fieldName) {
       _thriftId = thriftId;
       _fieldName = fieldName;
     }
-
+    
     public short getThriftFieldId() {
       return _thriftId;
     }
-
+    
     public String getFieldName() {
       return _fieldName;
     }
   }
-
+  
   // isset id assignments
-
-  public static final java.util.Map<_Fields, FieldMetaData> metaDataMap;
+  
+  public static final java.util.Map<_Fields,FieldMetaData> metaDataMap;
   static {
-    java.util.Map<_Fields, FieldMetaData> tmpMap = new java.util.EnumMap<_Fields, FieldMetaData>(_Fields.class);
-    tmpMap.put(_Fields.LOGGER, new FieldMetaData("logger", TFieldRequirementType.DEFAULT, 
-        new FieldValueMetaData(TType.STRING)));
+    java.util.Map<_Fields,FieldMetaData> tmpMap = new java.util.EnumMap<_Fields,FieldMetaData>(_Fields.class);
+    tmpMap.put(_Fields.LOGGER, new FieldMetaData("logger", TFieldRequirementType.DEFAULT, new FieldValueMetaData(TType.STRING)));
     metaDataMap = java.util.Collections.unmodifiableMap(tmpMap);
     FieldMetaData.addStructMetaDataMap(LoggerStatus.class, metaDataMap);
   }
-
-  public LoggerStatus() {
-  }
-
-  public LoggerStatus(
-    String logger)
-  {
+  
+  public LoggerStatus() {}
+  
+  public LoggerStatus(String logger) {
     this();
     this.logger = logger;
   }
-
+  
   /**
    * Performs a deep copy on <i>other</i>.
    */
@@ -106,96 +100,96 @@ public class LoggerStatus implements TBa
       this.logger = other.logger;
     }
   }
-
+  
   public LoggerStatus deepCopy() {
     return new LoggerStatus(this);
   }
-
+  
   @Deprecated
   public LoggerStatus clone() {
     return new LoggerStatus(this);
   }
-
+  
   public String getLogger() {
     return this.logger;
   }
-
+  
   public LoggerStatus setLogger(String logger) {
     this.logger = logger;
     return this;
   }
-
+  
   public void unsetLogger() {
     this.logger = null;
   }
-
+  
   /** Returns true if field logger is set (has been asigned a value) and false otherwise */
   public boolean isSetLogger() {
     return this.logger != null;
   }
-
+  
   public void setLoggerIsSet(boolean value) {
     if (!value) {
       this.logger = null;
     }
   }
-
+  
   public void setFieldValue(_Fields field, Object value) {
     switch (field) {
-    case LOGGER:
-      if (value == null) {
-        unsetLogger();
-      } else {
-        setLogger((String)value);
-      }
-      break;
-
+      case LOGGER:
+        if (value == null) {
+          unsetLogger();
+        } else {
+          setLogger((String) value);
+        }
+        break;
+    
     }
   }
-
+  
   public void setFieldValue(int fieldID, Object value) {
     setFieldValue(_Fields.findByThriftIdOrThrow(fieldID), value);
   }
-
+  
   public Object getFieldValue(_Fields field) {
     switch (field) {
-    case LOGGER:
-      return getLogger();
-
+      case LOGGER:
+        return getLogger();
+        
     }
     throw new IllegalStateException();
   }
-
+  
   public Object getFieldValue(int fieldId) {
     return getFieldValue(_Fields.findByThriftIdOrThrow(fieldId));
   }
-
+  
   /** Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise */
   public boolean isSet(_Fields field) {
     switch (field) {
-    case LOGGER:
-      return isSetLogger();
+      case LOGGER:
+        return isSetLogger();
     }
     throw new IllegalStateException();
   }
-
+  
   public boolean isSet(int fieldID) {
     return isSet(_Fields.findByThriftIdOrThrow(fieldID));
   }
-
+  
   @Override
   public boolean equals(Object that) {
     if (that == null)
       return false;
     if (that instanceof LoggerStatus)
-      return this.equals((LoggerStatus)that);
+      return this.equals((LoggerStatus) that);
     return false;
   }
-
+  
   public boolean equals(LoggerStatus that) {
     if (that == null)
       return false;
-
+    
     boolean this_present_logger = true && this.isSetLogger();
     boolean that_present_logger = true && that.isSetLogger();
     if (this_present_logger || that_present_logger) {
@@ -204,49 +198,49 @@ public class LoggerStatus implements TBa
       if (!this.logger.equals(that.logger))
         return false;
     }
-
+    
     return true;
   }
-
+  
   @Override
   public int hashCode() {
     return 0;
   }
-
+  
   public int compareTo(LoggerStatus other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
-
+    
     int lastComparison = 0;
-    LoggerStatus typedOther = (LoggerStatus)other;
-
+    LoggerStatus typedOther = (LoggerStatus) other;
+    
     lastComparison = Boolean.valueOf(isSetLogger()).compareTo(typedOther.isSetLogger());
     if (lastComparison != 0) {
       return lastComparison;
     }
-    if (isSetLogger()) {      lastComparison = TBaseHelper.compareTo(this.logger, typedOther.logger);
+    if (isSetLogger()) {
+      lastComparison = TBaseHelper.compareTo(this.logger, typedOther.logger);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
     return 0;
   }
-
+  
   public void read(TProtocol iprot) throws TException {
     TField field;
     iprot.readStructBegin();
-    while (true)
-    {
+    while (true) {
       field = iprot.readFieldBegin();
-      if (field.type == TType.STOP) { 
+      if (field.type == TType.STOP) {
         break;
       }
       switch (field.id) {
         case 1: // LOGGER
           if (field.type == TType.STRING) {
             this.logger = iprot.readString();
-          } else { 
+          } else {
             TProtocolUtil.skip(iprot, field.type);
           }
           break;
@@ -256,14 +250,14 @@ public class LoggerStatus implements TBa
       iprot.readFieldEnd();
     }
     iprot.readStructEnd();
-
+    
     // check for required fields of primitive type, which can't be checked in the validate method
     validate();
   }
-
+  
   public void write(TProtocol oprot) throws TException {
     validate();
-
+    
     oprot.writeStructBegin(STRUCT_DESC);
     if (this.logger != null) {
       oprot.writeFieldBegin(LOGGER_FIELD_DESC);
@@ -273,7 +267,7 @@ public class LoggerStatus implements TBa
     oprot.writeFieldStop();
     oprot.writeStructEnd();
   }
-
+  
   @Override
   public String toString() {
     StringBuilder sb = new StringBuilder("LoggerStatus(");
@@ -286,10 +280,9 @@ public class LoggerStatus implements TBa
     sb.append(")");
     return sb.toString();
   }
-
+  
   public void validate() throws TException {
     // check for required fields
   }
-
+  
 }
-