You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@accumulo.apache.org by el...@apache.org on 2014/09/26 19:12:08 UTC

[3/3] git commit: Merge branch '1.6.2-SNAPSHOT'

Merge branch '1.6.2-SNAPSHOT'

Conflicts:
	test/src/test/java/org/apache/accumulo/test/BadDeleteMarkersCreatedIT.java


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

Branch: refs/heads/master
Commit: ed337762621b24f5696243efabdabbc0201b2eea
Parents: 72dd8e1 b43abcb
Author: Josh Elser <el...@apache.org>
Authored: Fri Sep 26 13:11:52 2014 -0400
Committer: Josh Elser <el...@apache.org>
Committed: Fri Sep 26 13:11:52 2014 -0400

----------------------------------------------------------------------
 .../test/BadDeleteMarkersCreatedIT.java         | 11 ++-
 .../test/ConfigurableMajorCompactionIT.java     |  7 +-
 .../accumulo/test/functional/LargeRowIT.java    | 89 ++++++++++++--------
 .../accumulo/test/functional/MergeIT.java       | 11 ++-
 .../accumulo/test/functional/PermissionsIT.java |  9 +-
 5 files changed, 81 insertions(+), 46 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/ed337762/test/src/test/java/org/apache/accumulo/test/BadDeleteMarkersCreatedIT.java
----------------------------------------------------------------------
diff --cc test/src/test/java/org/apache/accumulo/test/BadDeleteMarkersCreatedIT.java
index 2add8c8,0000000..7d032c1
mode 100644,000000..100644
--- a/test/src/test/java/org/apache/accumulo/test/BadDeleteMarkersCreatedIT.java
+++ b/test/src/test/java/org/apache/accumulo/test/BadDeleteMarkersCreatedIT.java
@@@ -1,75 -1,0 +1,80 @@@
 +/*
 + * 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.test;
 +
 +import java.util.Map.Entry;
 +import java.util.SortedSet;
 +import java.util.TreeSet;
 +
 +import org.apache.accumulo.core.client.Connector;
 +import org.apache.accumulo.core.client.Scanner;
 +import org.apache.accumulo.core.conf.Property;
 +import org.apache.accumulo.core.data.Key;
 +import org.apache.accumulo.core.data.Value;
 +import org.apache.accumulo.core.metadata.MetadataTable;
 +import org.apache.accumulo.core.metadata.schema.MetadataSchema;
 +import org.apache.accumulo.core.security.Authorizations;
 +import org.apache.accumulo.core.util.UtilWaitThread;
 +import org.apache.accumulo.minicluster.impl.MiniAccumuloConfigImpl;
 +import org.apache.accumulo.test.functional.ConfigurableMacIT;
 +import org.apache.hadoop.conf.Configuration;
 +import org.apache.hadoop.io.Text;
 +import org.junit.Assert;
 +import org.junit.Test;
 +
 +// Accumulo3047
 +public class BadDeleteMarkersCreatedIT extends ConfigurableMacIT {
-   
++
++  @Override
++  public int defaultTimeoutSeconds() {
++    return 60;
++  }
++
 +  @Override
 +  public void configure(MiniAccumuloConfigImpl cfg, Configuration hadoopCoreSite) {
 +    cfg.setNumTservers(1);
 +    cfg.setProperty(Property.GC_CYCLE_DELAY, "1s");
 +    cfg.setProperty(Property.GC_CYCLE_START, "0s");
 +  }
 +
-   @Test(timeout= 60 * 1000)
++  @Test
 +  public void test() throws Exception {
 +    // make a table
 +    String tableName = getUniqueNames(1)[0];
 +    Connector c = getConnector();
 +    c.tableOperations().create(tableName);
 +    // add some splits
 +    SortedSet<Text> splits = new TreeSet<Text>();
 +    for (int i = 0; i < 10; i++) {
 +      splits.add(new Text("" + i));
 +    }
 +    c.tableOperations().addSplits(tableName, splits);
 +    // get rid of all the splits
 +    c.tableOperations().deleteRows(tableName, null, null);
 +    // get rid of the table
 +    c.tableOperations().delete(tableName);
 +    // let gc run
 +    UtilWaitThread.sleep(5 * 1000);
 +    // look for delete markers
 +    Scanner scanner = c.createScanner(MetadataTable.NAME, Authorizations.EMPTY);
 +    scanner.setRange(MetadataSchema.DeletesSection.getRange());
 +    for (Entry<Key,Value> entry : scanner) {
 +      Assert.fail(entry.getKey().getRow().toString());
 +    }
 +  }
-   
++
 +}

http://git-wip-us.apache.org/repos/asf/accumulo/blob/ed337762/test/src/test/java/org/apache/accumulo/test/functional/LargeRowIT.java
----------------------------------------------------------------------
diff --cc test/src/test/java/org/apache/accumulo/test/functional/LargeRowIT.java
index ea09018,32f8539..180da8e
--- a/test/src/test/java/org/apache/accumulo/test/functional/LargeRowIT.java
+++ b/test/src/test/java/org/apache/accumulo/test/functional/LargeRowIT.java
@@@ -100,48 -113,48 +115,48 @@@ public class LargeRowIT extends Configu
    private void test2(Connector c) throws Exception {
      basicTest(c, PRE_SPLIT_TABLE_NAME, NUM_PRE_SPLITS);
    }
-   
+ 
    private void basicTest(Connector c, String table, int expectedSplits) throws Exception {
      BatchWriter bw = c.createBatchWriter(table, new BatchWriterConfig());
-     
+ 
      Random r = new Random();
      byte rowData[] = new byte[ROW_SIZE];
-     
+ 
      r.setSeed(SEED);
-     
+ 
      for (int i = 0; i < NUM_ROWS; i++) {
-       
+ 
        r.nextBytes(rowData);
        TestIngest.toPrintableChars(rowData);
-       
+ 
        Mutation mut = new Mutation(new Text(rowData));
 -      mut.put(new Text(""), new Text(""), new Value(Integer.toString(i).getBytes(Constants.UTF8)));
 +      mut.put(new Text(""), new Text(""), new Value(Integer.toString(i).getBytes(StandardCharsets.UTF_8)));
        bw.addMutation(mut);
      }
-     
+ 
      bw.close();
-     
+ 
      FunctionalTestUtils.checkSplits(c, table, expectedSplits, expectedSplits);
-     
+ 
      verify(c, table);
-     
+ 
      FunctionalTestUtils.checkSplits(c, table, expectedSplits, expectedSplits);
-     
+ 
      c.tableOperations().flush(table, null, null, false);
-     
+ 
      // verify while table flush is running
      verify(c, table);
-     
+ 
      // give split time to complete
      c.tableOperations().flush(table, null, null, true);
-     
+ 
      FunctionalTestUtils.checkSplits(c, table, expectedSplits, expectedSplits);
-     
+ 
      verify(c, table);
-     
+ 
      FunctionalTestUtils.checkSplits(c, table, expectedSplits, expectedSplits);
    }
-   
+ 
    private void verify(Connector c, String table) throws Exception {
      Random r = new Random();
      byte rowData[] = new byte[ROW_SIZE];