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 2012/10/29 16:22:31 UTC

svn commit: r1403360 [7/7] - in /accumulo/branches/ACCUMULO-259: ./ assemble/ assemble/platform/debian/ assemble/platform/debian/init.d/ bin/ conf/ conf/examples/1GB/native-standalone/ conf/examples/1GB/standalone/ conf/examples/2GB/native-standalone/ ...

Modified: accumulo/branches/ACCUMULO-259/core/src/main/java/org/apache/accumulo/core/util/shell/commands/ConfigCommand.java
URL: http://svn.apache.org/viewvc/accumulo/branches/ACCUMULO-259/core/src/main/java/org/apache/accumulo/core/util/shell/commands/ConfigCommand.java?rev=1403360&r1=1403359&r2=1403360&view=diff
==============================================================================
--- accumulo/branches/ACCUMULO-259/core/src/main/java/org/apache/accumulo/core/util/shell/commands/ConfigCommand.java (original)
+++ accumulo/branches/ACCUMULO-259/core/src/main/java/org/apache/accumulo/core/util/shell/commands/ConfigCommand.java Mon Oct 29 15:22:24 2012
@@ -35,6 +35,7 @@ import org.apache.accumulo.core.security
 import org.apache.accumulo.core.util.BadArgumentException;
 import org.apache.accumulo.core.util.shell.Shell;
 import org.apache.accumulo.core.util.shell.Shell.Command;
+import org.apache.accumulo.core.util.shell.Shell.PrintFile;
 import org.apache.accumulo.core.util.shell.Token;
 import org.apache.commons.cli.CommandLine;
 import org.apache.commons.cli.Option;
@@ -42,7 +43,7 @@ import org.apache.commons.cli.OptionGrou
 import org.apache.commons.cli.Options;
 
 public class ConfigCommand extends Command {
-  private Option tableOpt, deleteOpt, setOpt, filterOpt, disablePaginationOpt;
+  private Option tableOpt, deleteOpt, setOpt, filterOpt, disablePaginationOpt, outputFileOpt;
   
   private int COL1 = 8, COL2 = 7;
   private ConsoleReader reader;
@@ -60,8 +61,8 @@ public class ConfigCommand extends Comma
     root.addSubcommand(cmd);
   }
   
-  public int execute(final String fullCommand, final CommandLine cl, final Shell shellState) throws AccumuloException, AccumuloSecurityException, TableNotFoundException,
-      IOException, ClassNotFoundException {
+  public int execute(final String fullCommand, final CommandLine cl, final Shell shellState) throws AccumuloException, AccumuloSecurityException,
+      TableNotFoundException, IOException, ClassNotFoundException {
     reader = shellState.getReader();
     
     final String tableName = cl.getOptionValue(tableOpt.getOpt());
@@ -77,7 +78,7 @@ public class ConfigCommand extends Comma
       if (tableName != null) {
         if (!Property.isValidTablePropertyKey(property)) {
           Shell.log.warn("Invalid per-table property : " + property + ", still removing from zookeeper if it's there.");
-        }        
+        }
         shellState.getConnector().tableOperations().removeProperty(tableName, property);
         Shell.log.debug("Successfully deleted table configuration option.");
       } else {
@@ -92,7 +93,7 @@ public class ConfigCommand extends Comma
       String property = cl.getOptionValue(setOpt.getOpt()), value = null;
       if (!property.contains("=")) {
         throw new BadArgumentException("Missing '=' operator in set operation.", fullCommand, fullCommand.indexOf(property));
-      }     
+      }
       final String pair[] = property.split("=", 2);
       property = pair[0];
       value = pair[1];
@@ -100,7 +101,7 @@ public class ConfigCommand extends Comma
       if (tableName != null) {
         if (!Property.isValidTablePropertyKey(property)) {
           throw new BadArgumentException("Invalid per-table property.", fullCommand, fullCommand.indexOf(property));
-        }   
+        }
         if (property.equals(Property.TABLE_DEFAULT_SCANTIME_VISIBILITY.getKey())) {
           new ColumnVisibility(value); // validate that it is a valid expression
         }
@@ -118,6 +119,9 @@ public class ConfigCommand extends Comma
       final TreeMap<String,String> systemConfig = new TreeMap<String,String>();
       systemConfig.putAll(shellState.getConnector().instanceOperations().getSystemConfiguration());
       
+      final String outputFile = cl.getOptionValue(outputFileOpt.getOpt());
+      final PrintFile printFile = outputFile == null ? null : new PrintFile(outputFile);
+      
       final TreeMap<String,String> siteConfig = new TreeMap<String,String>();
       siteConfig.putAll(shellState.getConnector().instanceOperations().getSiteConfiguration());
       
@@ -191,7 +195,10 @@ public class ConfigCommand extends Comma
         }
       }
       printConfFooter(output);
-      shellState.printLines(output.iterator(), !cl.hasOption(disablePaginationOpt.getOpt()));
+      shellState.printLines(output.iterator(), !cl.hasOption(disablePaginationOpt.getOpt()), printFile);
+      if (printFile != null) {
+        printFile.close();
+      }
     }
     return 0;
   }
@@ -230,11 +237,13 @@ public class ConfigCommand extends Comma
     setOpt = new Option("s", "set", true, "set a per-table property");
     filterOpt = new Option("f", "filter", true, "show only properties that contain this string");
     disablePaginationOpt = new Option("np", "no-pagination", false, "disables pagination of output");
-    
+    outputFileOpt = new Option("o", "output", true, "local file to write the scan output to");
+
     tableOpt.setArgName("table");
     deleteOpt.setArgName("property");
     setOpt.setArgName("property=value");
     filterOpt.setArgName("string");
+    outputFileOpt.setArgName("file");
     
     og.addOption(deleteOpt);
     og.addOption(setOpt);
@@ -243,6 +252,7 @@ public class ConfigCommand extends Comma
     o.addOption(tableOpt);
     o.addOptionGroup(og);
     o.addOption(disablePaginationOpt);
+    o.addOption(outputFileOpt);
     
     return o;
   }

Propchange: accumulo/branches/ACCUMULO-259/core/src/main/java/org/apache/accumulo/core/util/shell/commands/ExportTableCommand.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: accumulo/branches/ACCUMULO-259/core/src/main/java/org/apache/accumulo/core/util/shell/commands/ImportTableCommand.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: accumulo/branches/ACCUMULO-259/core/src/main/java/org/apache/accumulo/core/util/shell/commands/InterpreterCommand.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: accumulo/branches/ACCUMULO-259/core/src/main/java/org/apache/accumulo/core/util/shell/commands/ScanCommand.java
URL: http://svn.apache.org/viewvc/accumulo/branches/ACCUMULO-259/core/src/main/java/org/apache/accumulo/core/util/shell/commands/ScanCommand.java?rev=1403360&r1=1403359&r2=1403360&view=diff
==============================================================================
--- accumulo/branches/ACCUMULO-259/core/src/main/java/org/apache/accumulo/core/util/shell/commands/ScanCommand.java (original)
+++ accumulo/branches/ACCUMULO-259/core/src/main/java/org/apache/accumulo/core/util/shell/commands/ScanCommand.java Mon Oct 29 15:22:24 2012
@@ -38,6 +38,7 @@ import org.apache.accumulo.core.util.int
 import org.apache.accumulo.core.util.interpret.ScanInterpreter;
 import org.apache.accumulo.core.util.shell.Shell;
 import org.apache.accumulo.core.util.shell.Shell.Command;
+import org.apache.accumulo.core.util.shell.Shell.PrintFile;
 import org.apache.accumulo.start.classloader.AccumuloClassLoader;
 import org.apache.commons.cli.CommandLine;
 import org.apache.commons.cli.Option;
@@ -46,13 +47,19 @@ import org.apache.hadoop.io.Text;
 
 public class ScanCommand extends Command {
   
-  private Option scanOptAuths, scanOptRow, scanOptColumns, disablePaginationOpt, showFewOpt, formatterOpt, interpreterOpt, formatterInterpeterOpt;
+  private Option scanOptAuths, scanOptRow, scanOptColumns, disablePaginationOpt, showFewOpt, formatterOpt, interpreterOpt, formatterInterpeterOpt,
+      outputFileOpt;
+  
   protected Option timestampOpt;
   private Option optStartRowExclusive;
   private Option optEndRowExclusive;
   private Option timeoutOption;
   
   public int execute(final String fullCommand, final CommandLine cl, final Shell shellState) throws Exception {
+
+    final String outputFile = cl.getOptionValue(outputFileOpt.getOpt());
+    final PrintFile printFile = outputFile == null ? null : new PrintFile(outputFile);
+    
     final String tableName = OptUtil.getTableOpt(cl, shellState);
     
     final Class<? extends Formatter> formatter = getFormatter(cl, tableName, shellState);
@@ -84,7 +91,7 @@ public class ScanCommand extends Command
           throw new IllegalArgumentException();
         }
         BinaryFormatter.getlength(length);
-        printBinaryRecords(cl, shellState, scanner);
+        printBinaryRecords(cl, shellState, scanner, printFile);
       } catch (NumberFormatException nfe) {
         shellState.getReader().printString("Arg must be an integer. \n");
       } catch (IllegalArgumentException iae) {
@@ -92,7 +99,10 @@ public class ScanCommand extends Command
       }
       
     } else {
-        printRecords(cl, shellState, scanner, formatter);
+      printRecords(cl, shellState, scanner, formatter, printFile);
+    }
+    if (printFile != null) {
+      printFile.close();
     }
     
     return 0;
@@ -124,12 +134,31 @@ public class ScanCommand extends Command
     }
   }
   
-  protected void printRecords(final CommandLine cl, final Shell shellState, final Iterable<Entry<Key,Value>> scanner, final Class<? extends Formatter> formatter) throws IOException {
-    shellState.printRecords(scanner, cl.hasOption(timestampOpt.getOpt()), !cl.hasOption(disablePaginationOpt.getOpt()), formatter);
+  protected void printRecords(final CommandLine cl, final Shell shellState, final Iterable<Entry<Key,Value>> scanner, final Class<? extends Formatter> formatter)
+      throws IOException {
+    printRecords(cl, shellState, scanner, formatter, null);
   }
   
+  protected void printRecords(final CommandLine cl, final Shell shellState, final Iterable<Entry<Key,Value>> scanner,
+      final Class<? extends Formatter> formatter, PrintFile outFile) throws IOException {
+    if (outFile == null) {
+      shellState.printRecords(scanner, cl.hasOption(timestampOpt.getOpt()), !cl.hasOption(disablePaginationOpt.getOpt()), formatter);
+    } else {
+      shellState.printRecords(scanner, cl.hasOption(timestampOpt.getOpt()), !cl.hasOption(disablePaginationOpt.getOpt()), formatter, outFile);
+    }
+  }
+
   protected void printBinaryRecords(final CommandLine cl, final Shell shellState, final Iterable<Entry<Key,Value>> scanner) throws IOException {
-    shellState.printBinaryRecords(scanner, cl.hasOption(timestampOpt.getOpt()), !cl.hasOption(disablePaginationOpt.getOpt()));
+    printBinaryRecords(cl, shellState, scanner, null);
+  }
+  
+  protected void printBinaryRecords(final CommandLine cl, final Shell shellState, final Iterable<Entry<Key,Value>> scanner, PrintFile outFile)
+      throws IOException {
+    if (outFile == null) {
+      shellState.printBinaryRecords(scanner, cl.hasOption(timestampOpt.getOpt()), !cl.hasOption(disablePaginationOpt.getOpt()));
+    } else {
+      shellState.printBinaryRecords(scanner, cl.hasOption(timestampOpt.getOpt()), !cl.hasOption(disablePaginationOpt.getOpt()), outFile);
+    }
   }
   
   protected ScanInterpreter getInterpreter(final CommandLine cl, final String tableName, final Shell shellState) throws Exception {
@@ -239,6 +268,7 @@ public class ScanCommand extends Command
     formatterInterpeterOpt = new Option("fi", "fmt-interpreter", true, "fully qualified name of a class that is a formatter and interpreter");
     timeoutOption = new Option(null, "timeout", true,
         "time before scan should fail if no data is returned. If no unit is given assumes seconds.  Units d,h,m,s,and ms are supported.  e.g. 30s or 100ms");
+    outputFileOpt = new Option("o", "output", true, "local file to write the scan output to");
     
     scanOptAuths.setArgName("comma-separated-authorizations");
     scanOptRow.setArgName("row");
@@ -247,6 +277,7 @@ public class ScanCommand extends Command
     showFewOpt.setArgName("int");
     formatterOpt.setArgName("className");
     timeoutOption.setArgName("timeout");
+    outputFileOpt.setArgName("file");
     
     o.addOption(scanOptAuths);
     o.addOption(scanOptRow);
@@ -263,6 +294,7 @@ public class ScanCommand extends Command
     o.addOption(interpreterOpt);
     o.addOption(formatterInterpeterOpt);
     o.addOption(timeoutOption);
+    o.addOption(outputFileOpt);
     
     return o;
   }

Propchange: accumulo/branches/ACCUMULO-259/core/src/main/java/org/apache/accumulo/core/util/shell/commands/ShellPluginConfigurationCommand.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: accumulo/branches/ACCUMULO-259/core/src/main/java/org/apache/accumulo/core/zookeeper/ZooCache.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: accumulo/branches/ACCUMULO-259/core/src/main/thrift/client.thrift
URL: http://svn.apache.org/viewvc/accumulo/branches/ACCUMULO-259/core/src/main/thrift/client.thrift?rev=1403360&r1=1403359&r2=1403360&view=diff
==============================================================================
--- accumulo/branches/ACCUMULO-259/core/src/main/thrift/client.thrift (original)
+++ accumulo/branches/ACCUMULO-259/core/src/main/thrift/client.thrift Mon Oct 29 15:22:24 2012
@@ -94,3 +94,10 @@ service ClientService {
     map<string, string> getTableConfiguration(2:string tableName) throws (1:ThriftTableOperationException tope);
     bool checkClass(1:cloudtrace.TInfo tinfo, 2:string className, 3:string interfaceMatch);
 }
+
+// Only used for a unit test
+service ThriftTest {
+  bool success();
+  bool fails();
+  bool throwsError() throws (1:security.ThriftSecurityException ex);
+}

Modified: accumulo/branches/ACCUMULO-259/core/src/main/thrift/thrift.sh
URL: http://svn.apache.org/viewvc/accumulo/branches/ACCUMULO-259/core/src/main/thrift/thrift.sh?rev=1403360&r1=1403359&r2=1403360&view=diff
==============================================================================
--- accumulo/branches/ACCUMULO-259/core/src/main/thrift/thrift.sh (original)
+++ accumulo/branches/ACCUMULO-259/core/src/main/thrift/thrift.sh Mon Oct 29 15:22:24 2012
@@ -22,7 +22,7 @@ fail() {
 }
 
 # test to see if we have thrift installed
-VERSION=`thrift -version 2>/dev/null | grep "0.8" |  wc -l`
+VERSION=`thrift -version 2>/dev/null | grep "0.9" |  wc -l`
 if [ "$VERSION" -ne 1 ] ; then 
    # Nope: bail
    echo "***********************************************"

Modified: accumulo/branches/ACCUMULO-259/core/src/test/java/org/apache/accumulo/core/client/mapreduce/AccumuloInputFormatTest.java
URL: http://svn.apache.org/viewvc/accumulo/branches/ACCUMULO-259/core/src/test/java/org/apache/accumulo/core/client/mapreduce/AccumuloInputFormatTest.java?rev=1403360&r1=1403359&r2=1403360&view=diff
==============================================================================
--- accumulo/branches/ACCUMULO-259/core/src/test/java/org/apache/accumulo/core/client/mapreduce/AccumuloInputFormatTest.java (original)
+++ accumulo/branches/ACCUMULO-259/core/src/test/java/org/apache/accumulo/core/client/mapreduce/AccumuloInputFormatTest.java Mon Oct 29 15:22:24 2012
@@ -22,8 +22,6 @@ import static org.junit.Assert.assertTru
 import java.io.ByteArrayOutputStream;
 import java.io.DataOutputStream;
 import java.io.IOException;
-import java.util.ArrayList;
-import java.util.HashSet;
 import java.util.List;
 
 import org.apache.accumulo.core.client.BatchWriter;
@@ -34,7 +32,6 @@ import org.apache.accumulo.core.client.m
 import org.apache.accumulo.core.client.mock.MockInstance;
 import org.apache.accumulo.core.data.Key;
 import org.apache.accumulo.core.data.Mutation;
-import org.apache.accumulo.core.data.Range;
 import org.apache.accumulo.core.data.Value;
 import org.apache.accumulo.core.iterators.user.RegExFilter;
 import org.apache.accumulo.core.iterators.user.WholeRowIterator;
@@ -108,24 +105,6 @@ public class AccumuloInputFormatTest {
     String iterators = conf.get("AccumuloInputFormat.iterators");
     assertEquals(new String(Base64.encodeBase64(baos.toByteArray())), iterators);
   }
-
-  static abstract class GetRanges<K, V> extends InputFormatBase<K,V> {
-    public static List<Range> getRanges(Configuration conf) throws IOException {
-      return InputFormatBase.getRanges(conf);
-    }
-  };
-
-  @Test
-  public void testSetRanges() throws IOException {
-    JobContext job = ContextFactory.createJobContext();
-    List<Range> ranges = new ArrayList<Range>();
-    for (int i = 0; i < 100000; i++) {
-      ranges.add(new Range(new Text(String.format("%05x", i))));
-    }
-    AccumuloInputFormat.setRanges(job.getConfiguration(), ranges);
-    List<Range> ranges2 = GetRanges.getRanges(job.getConfiguration());
-    assertEquals(ranges, ranges2);
-  }
   
   @Test
   public void testAddIterator() {
@@ -247,17 +226,14 @@ public class AccumuloInputFormatTest {
   
   static class TestMapper extends Mapper<Key,Value,Key,Value> {
     Key key = null;
-    int first = 0;
     int count = 0;
     
     @Override
     protected void map(Key k, Value v, Context context) throws IOException, InterruptedException {
       if (key != null)
         assertEquals(key.getRow().toString(), new String(v.get()));
-      else
-        first = Integer.parseInt(k.getRow().toString(), 16) - 1;
-      assertEquals(k.getRow(), new Text(String.format("%09x", first + count + 1)));
-      assertEquals(new String(v.get()), String.format("%09x", first + count));
+      assertEquals(k.getRow(), new Text(String.format("%09x", count + 1)));
+      assertEquals(new String(v.get()), String.format("%09x", count));
       key = new Key(k);
       count++;
     }
@@ -282,14 +258,10 @@ public class AccumuloInputFormatTest {
     job.setNumReduceTasks(0);
     AccumuloInputFormat.setInputInfo(job.getConfiguration(), "root", "".getBytes(), "testtable", new Authorizations());
     AccumuloInputFormat.setMockInstance(job.getConfiguration(), "testmapinstance");
-    HashSet<Range> ranges = new HashSet<Range>();
-    ranges.add(new Range("000000000", "000000010"));
-    ranges.add(new Range("000000100", "000000110"));
-    AccumuloInputFormat.setRanges(job.getConfiguration(), ranges);
     
     AccumuloInputFormat input = new AccumuloInputFormat();
     List<InputSplit> splits = input.getSplits(job);
-    assertEquals(splits.size(), 2);
+    assertEquals(splits.size(), 1);
     
     TestMapper mapper = (TestMapper) job.getMapperClass().newInstance();
     for (InputSplit split : splits) {
@@ -298,7 +270,6 @@ public class AccumuloInputFormatTest {
       Mapper<Key,Value,Key,Value>.Context context = ContextFactory.createMapContext(mapper, tac, reader, null, split);
       reader.initialize(split, context);
       mapper.run(context);
-      assertEquals(mapper.count, 16);
     }
   }
   
@@ -319,9 +290,7 @@ public class AccumuloInputFormatTest {
     AccumuloInputFormat.setInputInfo(job.getConfiguration(), "root", "".getBytes(), "testtable2", new Authorizations());
     AccumuloInputFormat.setMockInstance(job.getConfiguration(), "testmapinstance");
     AccumuloInputFormat input = new AccumuloInputFormat();
-    List<InputSplit> splits = input.getSplits(job);
-    assertEquals(splits.size(), 1);
-    RangeInputSplit ris = (RangeInputSplit) splits.get(0);
+    RangeInputSplit ris = new RangeInputSplit();
     TaskAttemptContext tac = ContextFactory.createTaskAttemptContext(job);
     RecordReader<Key,Value> rr = input.createRecordReader(ris, tac);
     rr.initialize(ris, tac);
@@ -332,6 +301,5 @@ public class AccumuloInputFormatTest {
     while (rr.nextKeyValue()) {
       mapper.map(rr.getCurrentKey(), rr.getCurrentValue(), (TestMapper.Context) context);
     }
-    assertEquals(mapper.count, 100);
   }
 }

Modified: accumulo/branches/ACCUMULO-259/core/src/test/java/org/apache/accumulo/core/client/mock/MockTableOperationsTest.java
URL: http://svn.apache.org/viewvc/accumulo/branches/ACCUMULO-259/core/src/test/java/org/apache/accumulo/core/client/mock/MockTableOperationsTest.java?rev=1403360&r1=1403359&r2=1403360&view=diff
==============================================================================
--- accumulo/branches/ACCUMULO-259/core/src/test/java/org/apache/accumulo/core/client/mock/MockTableOperationsTest.java (original)
+++ accumulo/branches/ACCUMULO-259/core/src/test/java/org/apache/accumulo/core/client/mock/MockTableOperationsTest.java Mon Oct 29 15:22:24 2012
@@ -32,6 +32,7 @@ import org.apache.accumulo.core.client.A
 import org.apache.accumulo.core.client.AccumuloSecurityException;
 import org.apache.accumulo.core.client.BatchScanner;
 import org.apache.accumulo.core.client.BatchWriter;
+import org.apache.accumulo.core.client.BatchWriterConfig;
 import org.apache.accumulo.core.client.Connector;
 import org.apache.accumulo.core.client.Instance;
 import org.apache.accumulo.core.client.IteratorSetting;
@@ -101,7 +102,7 @@ public class MockTableOperationsTest {
     
     protected void writeVersionable(Connector c, String tableName, int size) throws TableNotFoundException, MutationsRejectedException {
         for (int i=0; i < size; i++) {
-            BatchWriter w = c.createBatchWriter(tableName, 100, 100, 1);
+            BatchWriter w = c.createBatchWriter(tableName, new BatchWriterConfig());
             Mutation m = new Mutation("row1");
             m.put("cf", "cq", String.valueOf(i));
             w.addMutation(m);

Propchange: accumulo/branches/ACCUMULO-259/core/src/test/java/org/apache/accumulo/core/file/rfile/RelativeKeyTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: accumulo/branches/ACCUMULO-259/core/src/test/java/org/apache/accumulo/core/iterators/FirstEntryInRowIteratorTest.java
URL: http://svn.apache.org/viewvc/accumulo/branches/ACCUMULO-259/core/src/test/java/org/apache/accumulo/core/iterators/FirstEntryInRowIteratorTest.java?rev=1403360&r1=1403359&r2=1403360&view=diff
==============================================================================
--- accumulo/branches/ACCUMULO-259/core/src/test/java/org/apache/accumulo/core/iterators/FirstEntryInRowIteratorTest.java (original)
+++ accumulo/branches/ACCUMULO-259/core/src/test/java/org/apache/accumulo/core/iterators/FirstEntryInRowIteratorTest.java Mon Oct 29 15:22:24 2012
@@ -1,3 +1,19 @@
+/*
+ * 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.iterators;
 
 import java.io.IOException;

Propchange: accumulo/branches/ACCUMULO-259/core/src/test/java/org/apache/accumulo/core/iterators/FirstEntryInRowIteratorTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: accumulo/branches/ACCUMULO-259/core/src/test/java/org/apache/accumulo/core/util/shell/command/FormatterCommandTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: accumulo/branches/ACCUMULO-259/docs/README_UBUNTU
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: accumulo/branches/ACCUMULO-259/docs/examples/README.export
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: accumulo/branches/ACCUMULO-259/docs/examples/README.maxmutation
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: accumulo/branches/ACCUMULO-259/docs/src/developer_manual/build.sh
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: accumulo/branches/ACCUMULO-259/examples/simple/src/main/java/org/apache/accumulo/examples/simple/mapreduce/UniqueColumns.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: accumulo/branches/ACCUMULO-259/fate/src/main/java/org/apache/accumulo/fate/ZooStore.java
------------------------------------------------------------------------------
  Merged /accumulo/branches/1.4/fate/src/main/java/org/apache/accumulo/fate/ZooStore.java:r1398801,1399211,1399717,1400976,1402571,1402682
  Merged /accumulo/trunk/fate/src/main/java/org/apache/accumulo/fate/ZooStore.java:r1398540-1403334
  Merged /accumulo/branches/1.4/src/fate/src/main/java/org/apache/accumulo/fate/ZooStore.java:r1399211,1400976,1402571,1402682

Propchange: accumulo/branches/ACCUMULO-259/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooSession.java
------------------------------------------------------------------------------
  Merged /accumulo/branches/1.4/src/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooSession.java:r1399211,1400976,1402571,1402682
  Merged /accumulo/trunk/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooSession.java:r1398540-1403334
  Merged /accumulo/branches/1.4/fate/src/main/java/org/apache/accumulo/fate/zookeeper/ZooSession.java:r1398801,1399211,1399717,1400976,1402571,1402682

Modified: accumulo/branches/ACCUMULO-259/pom.xml
URL: http://svn.apache.org/viewvc/accumulo/branches/ACCUMULO-259/pom.xml?rev=1403360&r1=1403359&r2=1403360&view=diff
==============================================================================
--- accumulo/branches/ACCUMULO-259/pom.xml (original)
+++ accumulo/branches/ACCUMULO-259/pom.xml Mon Oct 29 15:22:24 2012
@@ -178,8 +178,19 @@
       <plugin>
         <artifactId>maven-source-plugin</artifactId>
         <configuration>
+          <attach>true</attach>
           <outputDirectory>../lib</outputDirectory>
         </configuration>
+          <executions>
+            <execution>
+              <id>attach-sources</id>
+              <phase>package</phase>
+              <goals>
+                <goal>jar-no-fork</goal>
+                <goal>test-jar-no-fork</goal>
+              </goals>
+            </execution>
+          </executions>
       </plugin>
       <plugin>
         <artifactId>maven-surefire-plugin</artifactId>
@@ -589,7 +600,7 @@
       <dependency>
         <groupId>org.apache.thrift</groupId>
         <artifactId>libthrift</artifactId>
-        <version>0.8.0</version>
+        <version>0.9.0</version>
       </dependency>
       <dependency>
         <groupId>jline</groupId>

Propchange: accumulo/branches/ACCUMULO-259/server/
------------------------------------------------------------------------------
  Merged /accumulo/branches/1.4.2/src/server:r1399210,1402681
  Merged /accumulo/branches/1.4/server:r1398514,1398801,1399211,1399717,1400976,1402571,1402682
  Merged /accumulo/branches/1.4/src/server:r1399211,1400976,1402571,1402682
  Merged /accumulo/trunk/server:r1398540-1403334

Modified: accumulo/branches/ACCUMULO-259/server/src/main/c++/Makefile
URL: http://svn.apache.org/viewvc/accumulo/branches/ACCUMULO-259/server/src/main/c%2B%2B/Makefile?rev=1403360&r1=1403359&r2=1403360&view=diff
==============================================================================
--- accumulo/branches/ACCUMULO-259/server/src/main/c++/Makefile (original)
+++ accumulo/branches/ACCUMULO-259/server/src/main/c++/Makefile Mon Oct 29 15:22:24 2012
@@ -14,14 +14,10 @@
 # limitations under the License.
 
 # ya... I know, this is a bad recursive makefile...
-all: nm ml
+all: nm 
 
 nm: 
 	cd nativeMap ; $(MAKE)
 
-ml:
-	cd mlock ; $(MAKE)
-
 clean:
 	cd nativeMap ; $(MAKE) $@
-	cd mlock ; $(MAKE) $@

Modified: accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/data/ServerColumnUpdate.java
URL: http://svn.apache.org/viewvc/accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/data/ServerColumnUpdate.java?rev=1403360&r1=1403359&r2=1403360&view=diff
==============================================================================
--- accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/data/ServerColumnUpdate.java (original)
+++ accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/data/ServerColumnUpdate.java Mon Oct 29 15:22:24 2012
@@ -1,3 +1,19 @@
+/*
+ * 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.server.data;
 
 import org.apache.accumulo.core.data.ColumnUpdate;

Modified: accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/data/ServerMutation.java
URL: http://svn.apache.org/viewvc/accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/data/ServerMutation.java?rev=1403360&r1=1403359&r2=1403360&view=diff
==============================================================================
--- accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/data/ServerMutation.java (original)
+++ accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/data/ServerMutation.java Mon Oct 29 15:22:24 2012
@@ -1,3 +1,19 @@
+/*
+ * 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.server.data;
 
 import static org.apache.accumulo.core.data.Mutation.SERIALIZED_FORMAT.VERSION2;

Propchange: accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/master/tableOps/ExportTable.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/master/tableOps/ImportTable.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/metanalysis/FilterMeta.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/metanalysis/FindTablet.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/metanalysis/IndexMeta.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/metanalysis/LogFileInputFormat.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/metanalysis/LogFileOutputFormat.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/metanalysis/PrintEvents.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/metanalysis/package-info.java
URL: http://svn.apache.org/viewvc/accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/metanalysis/package-info.java?rev=1403360&r1=1403359&r2=1403360&view=diff
==============================================================================
--- accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/metanalysis/package-info.java (original)
+++ accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/metanalysis/package-info.java Mon Oct 29 15:22:24 2012
@@ -1,3 +1,19 @@
+/*
+ * 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.
+ */
 /**
  * Provides programs to analyze metadata mutations written to write ahead logs.  
  * 
@@ -15,4 +31,4 @@
  *
  * @since 1.5
  */
-package org.apache.accumulo.server.metanalysis;
\ No newline at end of file
+package org.apache.accumulo.server.metanalysis;

Propchange: accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/metanalysis/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/monitor/servlets/DefaultServlet.java
URL: http://svn.apache.org/viewvc/accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/monitor/servlets/DefaultServlet.java?rev=1403360&r1=1403359&r2=1403360&view=diff
==============================================================================
--- accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/monitor/servlets/DefaultServlet.java (original)
+++ accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/monitor/servlets/DefaultServlet.java Mon Oct 29 15:22:24 2012
@@ -370,7 +370,6 @@ public class DefaultServlet extends Basi
     try {
       InetSocketAddress address = JobTracker.getAddress(conf);
       
-      @SuppressWarnings("deprecation")
       // No alternative api in hadoop 20
       JobClient jc = new JobClient(new org.apache.hadoop.mapred.JobConf(conf));
       String httpAddress = conf.get("mapred.job.tracker.http.address");

Modified: accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/problems/ProblemReports.java
URL: http://svn.apache.org/viewvc/accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/problems/ProblemReports.java?rev=1403360&r1=1403359&r2=1403360&view=diff
==============================================================================
--- accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/problems/ProblemReports.java (original)
+++ accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/problems/ProblemReports.java Mon Oct 29 15:22:24 2012
@@ -210,7 +210,7 @@ public class ProblemReports implements I
                 Connector connector = HdfsZooInstance.getInstance().getConnector(SecurityConstants.getSystemCredentials());
                 Scanner scanner = connector.createScanner(Constants.METADATA_TABLE_NAME, Constants.NO_AUTHS);
                 
-                scanner.setTimeOut(3);
+                scanner.setTimeout(3, TimeUnit.SECONDS);
                 
                 if (table == null) {
                   scanner.setRange(new Range(new Text("~err_"), false, new Text("~err`"), false));

Propchange: accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/tabletserver/BulkFailedCopyProcessor.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/tabletserver/TabletMutations.java
URL: http://svn.apache.org/viewvc/accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/tabletserver/TabletMutations.java?rev=1403360&r1=1403359&r2=1403360&view=diff
==============================================================================
--- accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/tabletserver/TabletMutations.java (original)
+++ accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/tabletserver/TabletMutations.java Mon Oct 29 15:22:24 2012
@@ -1,3 +1,19 @@
+/*
+ * 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.server.tabletserver;
 
 import java.util.List;

Modified: accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/test/continuous/ContinuousStatsCollector.java
URL: http://svn.apache.org/viewvc/accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/test/continuous/ContinuousStatsCollector.java?rev=1403360&r1=1403359&r2=1403360&view=diff
==============================================================================
--- accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/test/continuous/ContinuousStatsCollector.java (original)
+++ accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/test/continuous/ContinuousStatsCollector.java Mon Oct 29 15:22:24 2012
@@ -160,7 +160,6 @@ public class ContinuousStatsCollector {
   
   private static String getMRStats() throws Exception {
     Configuration conf = CachedConfiguration.getInstance();
-    @SuppressWarnings("deprecation")
     // No alternatives for hadoop 20
     JobClient jc = new JobClient(new org.apache.hadoop.mapred.JobConf(conf));
     

Propchange: accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/test/continuous/GenSplits.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/test/functional/BadIteratorMincTest.java
URL: http://svn.apache.org/viewvc/accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/test/functional/BadIteratorMincTest.java?rev=1403360&r1=1403359&r2=1403360&view=diff
==============================================================================
--- accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/test/functional/BadIteratorMincTest.java (original)
+++ accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/test/functional/BadIteratorMincTest.java Mon Oct 29 15:22:24 2012
@@ -99,7 +99,7 @@ public class BadIteratorMincTest extends
     
     // now try putting bad iterator back and deleting the table
     getConnector().tableOperations().setProperty("foo", Property.TABLE_ITERATOR_PREFIX.getKey() + "minc.badi", "30," + BadIterator.class.getName());
-    bw = getConnector().createBatchWriter("foo", 1000000, 60000l, 2);
+    bw = getConnector().createBatchWriter("foo", new BatchWriterConfig());
     m = new Mutation(new Text("r2"));
     m.put(new Text("acf"), new Text("foo"), new Value("1".getBytes()));
     bw.addMutation(m);

Propchange: accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/test/functional/FateStarvationTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/test/functional/SlowConstraint.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/test/functional/SparseColumnFamilyTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/test/functional/TimeoutTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/test/performance/metadata/MetadataBatchScanTest.java
URL: http://svn.apache.org/viewvc/accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/test/performance/metadata/MetadataBatchScanTest.java?rev=1403360&r1=1403359&r2=1403360&view=diff
==============================================================================
--- accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/test/performance/metadata/MetadataBatchScanTest.java (original)
+++ accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/test/performance/metadata/MetadataBatchScanTest.java Mon Oct 29 15:22:24 2012
@@ -92,7 +92,7 @@ public class MetadataBatchScanTest {
       
       bw.close();
     } else if (args[0].equals("writeFiles")) {
-      BatchWriter bw = connector.createBatchWriter(Constants.METADATA_TABLE_NAME, 10000000, 60000l, 3);
+      BatchWriter bw = connector.createBatchWriter(Constants.METADATA_TABLE_NAME, new BatchWriterConfig());
       
       for (KeyExtent extent : extents) {
         

Modified: accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/test/randomwalk/concurrent/StartAll.java
URL: http://svn.apache.org/viewvc/accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/test/randomwalk/concurrent/StartAll.java?rev=1403360&r1=1403359&r2=1403360&view=diff
==============================================================================
--- accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/test/randomwalk/concurrent/StartAll.java (original)
+++ accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/test/randomwalk/concurrent/StartAll.java Mon Oct 29 15:22:24 2012
@@ -1,3 +1,19 @@
+/*
+ * 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.server.test.randomwalk.concurrent;
 
 import java.util.Properties;

Propchange: accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/test/randomwalk/concurrent/StartAll.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/test/randomwalk/concurrent/StopTabletServer.java
URL: http://svn.apache.org/viewvc/accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/test/randomwalk/concurrent/StopTabletServer.java?rev=1403360&r1=1403359&r2=1403360&view=diff
==============================================================================
--- accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/test/randomwalk/concurrent/StopTabletServer.java (original)
+++ accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/test/randomwalk/concurrent/StopTabletServer.java Mon Oct 29 15:22:24 2012
@@ -1,3 +1,19 @@
+/*
+ * 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.server.test.randomwalk.concurrent;
 
 import java.util.ArrayList;

Propchange: accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/test/randomwalk/concurrent/StopTabletServer.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/test/randomwalk/shard/CompactFilter.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/test/randomwalk/shard/DeleteSomeDocs.java
URL: http://svn.apache.org/viewvc/accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/test/randomwalk/shard/DeleteSomeDocs.java?rev=1403360&r1=1403359&r2=1403360&view=diff
==============================================================================
--- accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/test/randomwalk/shard/DeleteSomeDocs.java (original)
+++ accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/test/randomwalk/shard/DeleteSomeDocs.java Mon Oct 29 15:22:24 2012
@@ -23,6 +23,7 @@ import java.util.Random;
 
 import org.apache.accumulo.core.Constants;
 import org.apache.accumulo.core.client.BatchDeleter;
+import org.apache.accumulo.core.client.BatchWriterConfig;
 import org.apache.accumulo.core.client.IteratorSetting;
 import org.apache.accumulo.core.data.Range;
 import org.apache.accumulo.core.iterators.user.RegExFilter;
@@ -48,8 +49,8 @@ public class DeleteSomeDocs extends Test
         patterns.add(props.getProperty((String) key));
     
     String pattern = patterns.get(rand.nextInt(patterns.size()));
-    
-    BatchDeleter ibd = state.getConnector().createBatchDeleter(indexTableName, Constants.NO_AUTHS, 8, 100000000, 60000, 3);
+    BatchWriterConfig bwc = new BatchWriterConfig();
+    BatchDeleter ibd = state.getConnector().createBatchDeleter(indexTableName, Constants.NO_AUTHS, 8, bwc);
     ibd.setRanges(Collections.singletonList(new Range()));
     
     IteratorSetting iterSettings = new IteratorSetting(100, RegExFilter.class);
@@ -61,7 +62,7 @@ public class DeleteSomeDocs extends Test
     
     ibd.close();
     
-    BatchDeleter dbd = state.getConnector().createBatchDeleter(dataTableName, Constants.NO_AUTHS, 8, 100000000, 60000, 3);
+    BatchDeleter dbd = state.getConnector().createBatchDeleter(dataTableName, Constants.NO_AUTHS, 8, bwc);
     dbd.setRanges(Collections.singletonList(new Range()));
     
     iterSettings = new IteratorSetting(100, RegExFilter.class);

Propchange: accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/test/randomwalk/shard/ExportIndex.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/util/FindOfflineTablets.java
URL: http://svn.apache.org/viewvc/accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/util/FindOfflineTablets.java?rev=1403360&r1=1403359&r2=1403360&view=diff
==============================================================================
--- accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/util/FindOfflineTablets.java (original)
+++ accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/util/FindOfflineTablets.java Mon Oct 29 15:22:24 2012
@@ -1,3 +1,19 @@
+/*
+ * 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.server.util;
 
 import java.util.Set;

Propchange: accumulo/branches/ACCUMULO-259/server/src/main/java/org/apache/accumulo/server/zookeeper/DistributedWorkQueue.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: accumulo/branches/ACCUMULO-259/server/src/test/java/org/apache/accumulo/server/data/ServerMutationTest.java
URL: http://svn.apache.org/viewvc/accumulo/branches/ACCUMULO-259/server/src/test/java/org/apache/accumulo/server/data/ServerMutationTest.java?rev=1403360&r1=1403359&r2=1403360&view=diff
==============================================================================
--- accumulo/branches/ACCUMULO-259/server/src/test/java/org/apache/accumulo/server/data/ServerMutationTest.java (original)
+++ accumulo/branches/ACCUMULO-259/server/src/test/java/org/apache/accumulo/server/data/ServerMutationTest.java Mon Oct 29 15:22:24 2012
@@ -1,3 +1,19 @@
+/*
+ * 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.server.data;
 
 import static org.junit.Assert.assertEquals;

Modified: accumulo/branches/ACCUMULO-259/server/src/test/java/org/apache/accumulo/server/master/TestMergeState.java
URL: http://svn.apache.org/viewvc/accumulo/branches/ACCUMULO-259/server/src/test/java/org/apache/accumulo/server/master/TestMergeState.java?rev=1403360&r1=1403359&r2=1403360&view=diff
==============================================================================
--- accumulo/branches/ACCUMULO-259/server/src/test/java/org/apache/accumulo/server/master/TestMergeState.java (original)
+++ accumulo/branches/ACCUMULO-259/server/src/test/java/org/apache/accumulo/server/master/TestMergeState.java Mon Oct 29 15:22:24 2012
@@ -136,7 +136,7 @@ public class TestMergeState {
     Assert.assertEquals(MergeState.WAITING_FOR_OFFLINE, newState);
     
     // unassign the tablets
-    BatchDeleter deleter = connector.createBatchDeleter("!METADATA", Constants.NO_AUTHS, 1000, 1000l, 1000l, 1);
+    BatchDeleter deleter = connector.createBatchDeleter("!METADATA", Constants.NO_AUTHS, 1000, new BatchWriterConfig());
     deleter.fetchColumnFamily(Constants.METADATA_CURRENT_LOCATION_COLUMN_FAMILY);
     deleter.setRanges(Collections.singletonList(new Range()));
     deleter.delete();

Propchange: accumulo/branches/ACCUMULO-259/src/
------------------------------------------------------------------------------
  Merged /accumulo/branches/1.4.2/src:r1399210,1402681
  Merged /accumulo/trunk/src:r1398540-1403334
  Merged /accumulo/branches/1.4/src:r1398514,1398801,1399211,1399717,1400976,1402571,1402682
  Merged /accumulo/branches/1.4/src/src:r1399211,1400976,1402571,1402682

Propchange: accumulo/branches/ACCUMULO-259/test/compat/japi-compliance/README
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: accumulo/branches/ACCUMULO-259/test/compat/japi-compliance/japi-accumulo-1.4.xml
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: accumulo/branches/ACCUMULO-259/test/compat/japi-compliance/japi-accumulo-1.5.xml
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: accumulo/branches/ACCUMULO-259/test/system/auto/config.py
------------------------------------------------------------------------------
    svn:executable = *

Propchange: accumulo/branches/ACCUMULO-259/test/system/auto/simple/baditerminc.py
------------------------------------------------------------------------------
    svn:executable = *

Propchange: accumulo/branches/ACCUMULO-259/test/system/auto/simple/combiner.py
------------------------------------------------------------------------------
    svn:executable = *

Propchange: accumulo/branches/ACCUMULO-259/test/system/auto/simple/examples.py
------------------------------------------------------------------------------
    svn:executable = *

Propchange: accumulo/branches/ACCUMULO-259/test/system/auto/simple/fateStartvation.py
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: accumulo/branches/ACCUMULO-259/test/system/auto/simple/sparseColumnFamily.py
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: accumulo/branches/ACCUMULO-259/test/system/auto/simple/timeout.py
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: accumulo/branches/ACCUMULO-259/test/system/auto/simple/timeout.py
------------------------------------------------------------------------------
    svn:executable = *

Propchange: accumulo/branches/ACCUMULO-259/test/system/auto/stress/migrations.py
------------------------------------------------------------------------------
    svn:executable = *

Modified: accumulo/branches/ACCUMULO-259/test/system/continuous/agitator.pl
URL: http://svn.apache.org/viewvc/accumulo/branches/ACCUMULO-259/test/system/continuous/agitator.pl?rev=1403360&r1=1403359&r2=1403360&view=diff
==============================================================================
--- accumulo/branches/ACCUMULO-259/test/system/continuous/agitator.pl (original)
+++ accumulo/branches/ACCUMULO-259/test/system/continuous/agitator.pl Mon Oct 29 15:22:24 2012
@@ -57,6 +57,11 @@ if(scalar(@slaves) < $maxKill){
 	$maxKill = scalar(@slaves);
 }
 
+if ($minKill > $maxKill){
+    print STDERR "WARN setting minKill to equal maxKill\n";
+    $minKill = $maxKill;
+}
+
 while(1){
 
 	$numToKill = int(rand($maxKill - $minKill + 1)) + $minKill;

Propchange: accumulo/branches/ACCUMULO-259/test/system/randomwalk/bin/reset-cluster.sh
------------------------------------------------------------------------------
    svn:executable = *

Modified: accumulo/branches/ACCUMULO-259/trace/src/main/java/org/apache/accumulo/cloudtrace/thrift/RemoteSpan.java
URL: http://svn.apache.org/viewvc/accumulo/branches/ACCUMULO-259/trace/src/main/java/org/apache/accumulo/cloudtrace/thrift/RemoteSpan.java?rev=1403360&r1=1403359&r2=1403360&view=diff
==============================================================================
--- accumulo/branches/ACCUMULO-259/trace/src/main/java/org/apache/accumulo/cloudtrace/thrift/RemoteSpan.java (original)
+++ accumulo/branches/ACCUMULO-259/trace/src/main/java/org/apache/accumulo/cloudtrace/thrift/RemoteSpan.java Mon Oct 29 15:22:24 2012
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.8.0)
+ * Autogenerated by Thrift Compiler (0.9.0)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
@@ -12,6 +12,9 @@ import org.apache.thrift.scheme.Standard
 
 import org.apache.thrift.scheme.TupleScheme;
 import org.apache.thrift.protocol.TTupleProtocol;
+import org.apache.thrift.protocol.TProtocolException;
+import org.apache.thrift.EncodingUtils;
+import org.apache.thrift.TException;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -57,7 +60,7 @@ import org.slf4j.LoggerFactory;
   public Map<String,String> data; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     SENDER((short)1, "sender"),
     SVC((short)2, "svc"),
     TRACE_ID((short)3, "traceId"),
@@ -144,7 +147,7 @@ import org.slf4j.LoggerFactory;
   private static final int __PARENTID_ISSET_ID = 2;
   private static final int __START_ISSET_ID = 3;
   private static final int __STOP_ISSET_ID = 4;
-  private BitSet __isset_bit_vector = new BitSet(5);
+  private byte __isset_bitfield = 0;
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -207,8 +210,7 @@ import org.slf4j.LoggerFactory;
    * Performs a deep copy on <i>other</i>.
    */
   public RemoteSpan(RemoteSpan other) {
-    __isset_bit_vector.clear();
-    __isset_bit_vector.or(other.__isset_bit_vector);
+    __isset_bitfield = other.__isset_bitfield;
     if (other.isSetSender()) {
       this.sender = other.sender;
     }
@@ -321,16 +323,16 @@ import org.slf4j.LoggerFactory;
   }
 
   public void unsetTraceId() {
-    __isset_bit_vector.clear(__TRACEID_ISSET_ID);
+    __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __TRACEID_ISSET_ID);
   }
 
   /** Returns true if field traceId is set (has been assigned a value) and false otherwise */
   public boolean isSetTraceId() {
-    return __isset_bit_vector.get(__TRACEID_ISSET_ID);
+    return EncodingUtils.testBit(__isset_bitfield, __TRACEID_ISSET_ID);
   }
 
   public void setTraceIdIsSet(boolean value) {
-    __isset_bit_vector.set(__TRACEID_ISSET_ID, value);
+    __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __TRACEID_ISSET_ID, value);
   }
 
   public long getSpanId() {
@@ -344,16 +346,16 @@ import org.slf4j.LoggerFactory;
   }
 
   public void unsetSpanId() {
-    __isset_bit_vector.clear(__SPANID_ISSET_ID);
+    __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __SPANID_ISSET_ID);
   }
 
   /** Returns true if field spanId is set (has been assigned a value) and false otherwise */
   public boolean isSetSpanId() {
-    return __isset_bit_vector.get(__SPANID_ISSET_ID);
+    return EncodingUtils.testBit(__isset_bitfield, __SPANID_ISSET_ID);
   }
 
   public void setSpanIdIsSet(boolean value) {
-    __isset_bit_vector.set(__SPANID_ISSET_ID, value);
+    __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __SPANID_ISSET_ID, value);
   }
 
   public long getParentId() {
@@ -367,16 +369,16 @@ import org.slf4j.LoggerFactory;
   }
 
   public void unsetParentId() {
-    __isset_bit_vector.clear(__PARENTID_ISSET_ID);
+    __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __PARENTID_ISSET_ID);
   }
 
   /** Returns true if field parentId is set (has been assigned a value) and false otherwise */
   public boolean isSetParentId() {
-    return __isset_bit_vector.get(__PARENTID_ISSET_ID);
+    return EncodingUtils.testBit(__isset_bitfield, __PARENTID_ISSET_ID);
   }
 
   public void setParentIdIsSet(boolean value) {
-    __isset_bit_vector.set(__PARENTID_ISSET_ID, value);
+    __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __PARENTID_ISSET_ID, value);
   }
 
   public long getStart() {
@@ -390,16 +392,16 @@ import org.slf4j.LoggerFactory;
   }
 
   public void unsetStart() {
-    __isset_bit_vector.clear(__START_ISSET_ID);
+    __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __START_ISSET_ID);
   }
 
   /** Returns true if field start is set (has been assigned a value) and false otherwise */
   public boolean isSetStart() {
-    return __isset_bit_vector.get(__START_ISSET_ID);
+    return EncodingUtils.testBit(__isset_bitfield, __START_ISSET_ID);
   }
 
   public void setStartIsSet(boolean value) {
-    __isset_bit_vector.set(__START_ISSET_ID, value);
+    __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __START_ISSET_ID, value);
   }
 
   public long getStop() {
@@ -413,16 +415,16 @@ import org.slf4j.LoggerFactory;
   }
 
   public void unsetStop() {
-    __isset_bit_vector.clear(__STOP_ISSET_ID);
+    __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __STOP_ISSET_ID);
   }
 
   /** Returns true if field stop is set (has been assigned a value) and false otherwise */
   public boolean isSetStop() {
-    return __isset_bit_vector.get(__STOP_ISSET_ID);
+    return EncodingUtils.testBit(__isset_bitfield, __STOP_ISSET_ID);
   }
 
   public void setStopIsSet(boolean value) {
-    __isset_bit_vector.set(__STOP_ISSET_ID, value);
+    __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __STOP_ISSET_ID, value);
   }
 
   public String getDescription() {
@@ -900,6 +902,7 @@ import org.slf4j.LoggerFactory;
 
   public void validate() throws org.apache.thrift.TException {
     // check for required fields
+    // check for sub-struct validity
   }
 
   private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException {
@@ -913,7 +916,7 @@ import org.slf4j.LoggerFactory;
   private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException {
     try {
       // it doesn't seem like you should have to do this, but java serialization is wacky, and doesn't call the default constructor.
-      __isset_bit_vector = new BitSet(1);
+      __isset_bitfield = 0;
       read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in)));
     } catch (org.apache.thrift.TException te) {
       throw new java.io.IOException(te);

Modified: accumulo/branches/ACCUMULO-259/trace/src/main/java/org/apache/accumulo/cloudtrace/thrift/SpanReceiver.java
URL: http://svn.apache.org/viewvc/accumulo/branches/ACCUMULO-259/trace/src/main/java/org/apache/accumulo/cloudtrace/thrift/SpanReceiver.java?rev=1403360&r1=1403359&r2=1403360&view=diff
==============================================================================
--- accumulo/branches/ACCUMULO-259/trace/src/main/java/org/apache/accumulo/cloudtrace/thrift/SpanReceiver.java (original)
+++ accumulo/branches/ACCUMULO-259/trace/src/main/java/org/apache/accumulo/cloudtrace/thrift/SpanReceiver.java Mon Oct 29 15:22:24 2012
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.8.0)
+ * Autogenerated by Thrift Compiler (0.9.0)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
@@ -12,6 +12,9 @@ import org.apache.thrift.scheme.Standard
 
 import org.apache.thrift.scheme.TupleScheme;
 import org.apache.thrift.protocol.TTupleProtocol;
+import org.apache.thrift.protocol.TProtocolException;
+import org.apache.thrift.EncodingUtils;
+import org.apache.thrift.TException;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -139,16 +142,20 @@ import org.slf4j.LoggerFactory;
       return processMap;
     }
 
-    private static class span<I extends Iface> extends org.apache.thrift.ProcessFunction<I, span_args> {
+    public static class span<I extends Iface> extends org.apache.thrift.ProcessFunction<I, span_args> {
       public span() {
         super("span");
       }
 
-      protected span_args getEmptyArgsInstance() {
+      public span_args getEmptyArgsInstance() {
         return new span_args();
       }
 
-      protected org.apache.thrift.TBase getResult(I iface, span_args args) throws org.apache.thrift.TException {
+      protected boolean isOneway() {
+        return true;
+      }
+
+      public org.apache.thrift.TBase getResult(I iface, span_args args) throws org.apache.thrift.TException {
         iface.span(args.span);
         return null;
       }
@@ -170,7 +177,7 @@ import org.slf4j.LoggerFactory;
     public RemoteSpan span; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SPAN((short)1, "span");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -405,6 +412,10 @@ import org.slf4j.LoggerFactory;
 
     public void validate() throws org.apache.thrift.TException {
       // check for required fields
+      // check for sub-struct validity
+      if (span != null) {
+        span.validate();
+      }
     }
 
     private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException {

Modified: accumulo/branches/ACCUMULO-259/trace/src/main/java/org/apache/accumulo/cloudtrace/thrift/TInfo.java
URL: http://svn.apache.org/viewvc/accumulo/branches/ACCUMULO-259/trace/src/main/java/org/apache/accumulo/cloudtrace/thrift/TInfo.java?rev=1403360&r1=1403359&r2=1403360&view=diff
==============================================================================
--- accumulo/branches/ACCUMULO-259/trace/src/main/java/org/apache/accumulo/cloudtrace/thrift/TInfo.java (original)
+++ accumulo/branches/ACCUMULO-259/trace/src/main/java/org/apache/accumulo/cloudtrace/thrift/TInfo.java Mon Oct 29 15:22:24 2012
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.8.0)
+ * Autogenerated by Thrift Compiler (0.9.0)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
@@ -12,6 +12,9 @@ import org.apache.thrift.scheme.Standard
 
 import org.apache.thrift.scheme.TupleScheme;
 import org.apache.thrift.protocol.TTupleProtocol;
+import org.apache.thrift.protocol.TProtocolException;
+import org.apache.thrift.EncodingUtils;
+import org.apache.thrift.TException;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -43,7 +46,7 @@ import org.slf4j.LoggerFactory;
   public long parentId; // required
 
   /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+  @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
     TRACE_ID((short)1, "traceId"),
     PARENT_ID((short)2, "parentId");
 
@@ -106,7 +109,7 @@ import org.slf4j.LoggerFactory;
   // isset id assignments
   private static final int __TRACEID_ISSET_ID = 0;
   private static final int __PARENTID_ISSET_ID = 1;
-  private BitSet __isset_bit_vector = new BitSet(2);
+  private byte __isset_bitfield = 0;
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -136,8 +139,7 @@ import org.slf4j.LoggerFactory;
    * Performs a deep copy on <i>other</i>.
    */
   public TInfo(TInfo other) {
-    __isset_bit_vector.clear();
-    __isset_bit_vector.or(other.__isset_bit_vector);
+    __isset_bitfield = other.__isset_bitfield;
     this.traceId = other.traceId;
     this.parentId = other.parentId;
   }
@@ -165,16 +167,16 @@ import org.slf4j.LoggerFactory;
   }
 
   public void unsetTraceId() {
-    __isset_bit_vector.clear(__TRACEID_ISSET_ID);
+    __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __TRACEID_ISSET_ID);
   }
 
   /** Returns true if field traceId is set (has been assigned a value) and false otherwise */
   public boolean isSetTraceId() {
-    return __isset_bit_vector.get(__TRACEID_ISSET_ID);
+    return EncodingUtils.testBit(__isset_bitfield, __TRACEID_ISSET_ID);
   }
 
   public void setTraceIdIsSet(boolean value) {
-    __isset_bit_vector.set(__TRACEID_ISSET_ID, value);
+    __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __TRACEID_ISSET_ID, value);
   }
 
   public long getParentId() {
@@ -188,16 +190,16 @@ import org.slf4j.LoggerFactory;
   }
 
   public void unsetParentId() {
-    __isset_bit_vector.clear(__PARENTID_ISSET_ID);
+    __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __PARENTID_ISSET_ID);
   }
 
   /** Returns true if field parentId is set (has been assigned a value) and false otherwise */
   public boolean isSetParentId() {
-    return __isset_bit_vector.get(__PARENTID_ISSET_ID);
+    return EncodingUtils.testBit(__isset_bitfield, __PARENTID_ISSET_ID);
   }
 
   public void setParentIdIsSet(boolean value) {
-    __isset_bit_vector.set(__PARENTID_ISSET_ID, value);
+    __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __PARENTID_ISSET_ID, value);
   }
 
   public void setFieldValue(_Fields field, Object value) {
@@ -348,6 +350,7 @@ import org.slf4j.LoggerFactory;
 
   public void validate() throws org.apache.thrift.TException {
     // check for required fields
+    // check for sub-struct validity
   }
 
   private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException {
@@ -361,7 +364,7 @@ import org.slf4j.LoggerFactory;
   private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException {
     try {
       // it doesn't seem like you should have to do this, but java serialization is wacky, and doesn't call the default constructor.
-      __isset_bit_vector = new BitSet(1);
+      __isset_bitfield = 0;
       read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in)));
     } catch (org.apache.thrift.TException te) {
       throw new java.io.IOException(te);

Modified: accumulo/branches/ACCUMULO-259/trace/src/main/java/org/apache/accumulo/cloudtrace/thrift/TestService.java
URL: http://svn.apache.org/viewvc/accumulo/branches/ACCUMULO-259/trace/src/main/java/org/apache/accumulo/cloudtrace/thrift/TestService.java?rev=1403360&r1=1403359&r2=1403360&view=diff
==============================================================================
--- accumulo/branches/ACCUMULO-259/trace/src/main/java/org/apache/accumulo/cloudtrace/thrift/TestService.java (original)
+++ accumulo/branches/ACCUMULO-259/trace/src/main/java/org/apache/accumulo/cloudtrace/thrift/TestService.java Mon Oct 29 15:22:24 2012
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.8.0)
+ * Autogenerated by Thrift Compiler (0.9.0)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
@@ -12,6 +12,9 @@ import org.apache.thrift.scheme.Standard
 
 import org.apache.thrift.scheme.TupleScheme;
 import org.apache.thrift.protocol.TTupleProtocol;
+import org.apache.thrift.protocol.TProtocolException;
+import org.apache.thrift.EncodingUtils;
+import org.apache.thrift.TException;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -155,16 +158,20 @@ import org.slf4j.LoggerFactory;
       return processMap;
     }
 
-    private static class checkTrace<I extends Iface> extends org.apache.thrift.ProcessFunction<I, checkTrace_args> {
+    public static class checkTrace<I extends Iface> extends org.apache.thrift.ProcessFunction<I, checkTrace_args> {
       public checkTrace() {
         super("checkTrace");
       }
 
-      protected checkTrace_args getEmptyArgsInstance() {
+      public checkTrace_args getEmptyArgsInstance() {
         return new checkTrace_args();
       }
 
-      protected checkTrace_result getResult(I iface, checkTrace_args args) throws org.apache.thrift.TException {
+      protected boolean isOneway() {
+        return false;
+      }
+
+      public checkTrace_result getResult(I iface, checkTrace_args args) throws org.apache.thrift.TException {
         checkTrace_result result = new checkTrace_result();
         result.success = iface.checkTrace(args.tinfo, args.message);
         result.setSuccessIsSet(true);
@@ -190,7 +197,7 @@ import org.slf4j.LoggerFactory;
     public String message; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       TINFO((short)1, "tinfo"),
       MESSAGE((short)2, "message");
 
@@ -500,6 +507,10 @@ import org.slf4j.LoggerFactory;
 
     public void validate() throws org.apache.thrift.TException {
       // check for required fields
+      // check for sub-struct validity
+      if (tinfo != null) {
+        tinfo.validate();
+      }
     }
 
     private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException {
@@ -643,7 +654,7 @@ import org.slf4j.LoggerFactory;
     public boolean success; // required
 
     /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
-    public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    @SuppressWarnings("all") public enum _Fields implements org.apache.thrift.TFieldIdEnum {
       SUCCESS((short)0, "success");
 
       private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
@@ -702,7 +713,7 @@ import org.slf4j.LoggerFactory;
 
     // isset id assignments
     private static final int __SUCCESS_ISSET_ID = 0;
-    private BitSet __isset_bit_vector = new BitSet(1);
+    private byte __isset_bitfield = 0;
     public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
     static {
       Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -727,8 +738,7 @@ import org.slf4j.LoggerFactory;
      * Performs a deep copy on <i>other</i>.
      */
     public checkTrace_result(checkTrace_result other) {
-      __isset_bit_vector.clear();
-      __isset_bit_vector.or(other.__isset_bit_vector);
+      __isset_bitfield = other.__isset_bitfield;
       this.success = other.success;
     }
 
@@ -753,16 +763,16 @@ import org.slf4j.LoggerFactory;
     }
 
     public void unsetSuccess() {
-      __isset_bit_vector.clear(__SUCCESS_ISSET_ID);
+      __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __SUCCESS_ISSET_ID);
     }
 
     /** Returns true if field success is set (has been assigned a value) and false otherwise */
     public boolean isSetSuccess() {
-      return __isset_bit_vector.get(__SUCCESS_ISSET_ID);
+      return EncodingUtils.testBit(__isset_bitfield, __SUCCESS_ISSET_ID);
     }
 
     public void setSuccessIsSet(boolean value) {
-      __isset_bit_vector.set(__SUCCESS_ISSET_ID, value);
+      __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __SUCCESS_ISSET_ID, value);
     }
 
     public void setFieldValue(_Fields field, Object value) {
@@ -877,6 +887,7 @@ import org.slf4j.LoggerFactory;
 
     public void validate() throws org.apache.thrift.TException {
       // check for required fields
+      // check for sub-struct validity
     }
 
     private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException {
@@ -889,6 +900,8 @@ import org.slf4j.LoggerFactory;
 
     private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException {
       try {
+        // it doesn't seem like you should have to do this, but java serialization is wacky, and doesn't call the default constructor.
+        __isset_bitfield = 0;
         read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in)));
       } catch (org.apache.thrift.TException te) {
         throw new java.io.IOException(te);
@@ -936,9 +949,11 @@ import org.slf4j.LoggerFactory;
         struct.validate();
 
         oprot.writeStructBegin(STRUCT_DESC);
-        oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
-        oprot.writeBool(struct.success);
-        oprot.writeFieldEnd();
+        if (struct.isSetSuccess()) {
+          oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
+          oprot.writeBool(struct.success);
+          oprot.writeFieldEnd();
+        }
         oprot.writeFieldStop();
         oprot.writeStructEnd();
       }