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

[1/9] accumulo git commit: ACCUMULO-3877 Fix the test to acct for compactions over both tablets.

Repository: accumulo
Updated Branches:
  refs/heads/1.7 3289940fb -> d71e5ee4c
  refs/heads/master f6bd3eecd -> 5fbd67157


ACCUMULO-3877 Fix the test to acct for compactions over both tablets.


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

Branch: refs/heads/1.7
Commit: c100231a644a20b48aaa8014aa6c41dfa0781ed3
Parents: 3289940
Author: Josh Elser <el...@apache.org>
Authored: Mon Jun 1 13:05:28 2015 -0400
Committer: Josh Elser <el...@apache.org>
Committed: Mon Jun 1 13:05:28 2015 -0400

----------------------------------------------------------------------
 .../apache/accumulo/test/TableOperationsIT.java | 24 ++++++++++++++++----
 1 file changed, 20 insertions(+), 4 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/c100231a/test/src/test/java/org/apache/accumulo/test/TableOperationsIT.java
----------------------------------------------------------------------
diff --git a/test/src/test/java/org/apache/accumulo/test/TableOperationsIT.java b/test/src/test/java/org/apache/accumulo/test/TableOperationsIT.java
index ced9d69..dc8f9dd 100644
--- a/test/src/test/java/org/apache/accumulo/test/TableOperationsIT.java
+++ b/test/src/test/java/org/apache/accumulo/test/TableOperationsIT.java
@@ -61,7 +61,6 @@ import org.apache.accumulo.test.functional.BadIterator;
 import org.apache.hadoop.io.Text;
 import org.apache.thrift.TException;
 import org.junit.Assert;
-import org.junit.Assume;
 import org.junit.Before;
 import org.junit.Test;
 
@@ -305,9 +304,26 @@ public class TableOperationsIT extends AccumuloClusterIT {
     Map<Key,Value> actual = new TreeMap<>(COMPARE_KEY_TO_COLQ); // only compare row, colF, colQ
     for (Map.Entry<Key,Value> entry : scanner)
       actual.put(entry.getKey(), entry.getValue());
-    Assume
-        .assumeFalse("Compaction successfully occurred due to weird timing but we hoped it would cancel.", HardListIterator.allEntriesToInject.equals(actual));
-    assertTrue("Scan should be empty if compaction canceled. " + "Actual is " + actual, actual.isEmpty());
+    switch (actual.size()) {
+      case 3:
+        // Compaction cancel didn't happen in time
+        assertTrue(HardListIterator.allEntriesToInject.equals(actual));
+        break;
+      case 2:
+        // Compacted the first tablet (-inf, f)
+        assertEquals(HardListIterator.allEntriesToInject.headMap(new Key("f")), actual);
+        break;
+      case 1:
+        // Compacted the second tablet [f, +inf)
+        assertEquals(HardListIterator.allEntriesToInject.tailMap(new Key("f")), actual);
+        break;
+      case 0:
+        // Cancelled the compaction before it ran. No generated entries.
+        break;
+      default:
+        Assert.fail("Unexpected number of entries");
+        break;
+    }
     connector.tableOperations().delete(tableName);
   }
 


[6/9] accumulo git commit: ACCUMULO-3878 Add a missing list delimiter

Posted by el...@apache.org.
ACCUMULO-3878 Add a missing list delimiter


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

Branch: refs/heads/master
Commit: acb5d2e2bed89db4d0b294e987cde18d1689fd12
Parents: a31ada5
Author: Josh Elser <el...@apache.org>
Authored: Mon Jun 1 14:47:54 2015 -0400
Committer: Josh Elser <el...@apache.org>
Committed: Mon Jun 1 15:38:46 2015 -0400

----------------------------------------------------------------------
 .../minicluster/impl/MiniAccumuloClusterImpl.java         | 10 ++++++++--
 1 file changed, 8 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/acb5d2e2/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/MiniAccumuloClusterImpl.java
----------------------------------------------------------------------
diff --git a/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/MiniAccumuloClusterImpl.java b/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/MiniAccumuloClusterImpl.java
index 2e631b8..5ca0429 100644
--- a/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/MiniAccumuloClusterImpl.java
+++ b/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/MiniAccumuloClusterImpl.java
@@ -90,6 +90,7 @@ import org.apache.accumulo.server.util.time.SimpleTimer;
 import org.apache.accumulo.server.zookeeper.ZooReaderWriterFactory;
 import org.apache.accumulo.start.Main;
 import org.apache.accumulo.start.classloader.vfs.MiniDFSUtil;
+import org.apache.commons.configuration.AbstractConfiguration;
 import org.apache.commons.configuration.MapConfiguration;
 import org.apache.commons.io.FileUtils;
 import org.apache.commons.vfs2.FileObject;
@@ -728,8 +729,13 @@ public class MiniAccumuloClusterImpl implements AccumuloCluster {
 
   @Override
   public ClientConfiguration getClientConfig() {
-    return new ClientConfiguration(Arrays.asList(new MapConfiguration(config.getSiteConfig()))).withInstance(this.getInstanceName()).withZkHosts(
-        this.getZooKeepers());
+    return new ClientConfiguration(getConfigs(config)).withInstance(this.getInstanceName()).withZkHosts(this.getZooKeepers());
+  }
+
+  private static List<AbstractConfiguration> getConfigs(MiniAccumuloConfigImpl config) {
+    MapConfiguration cfg = new MapConfiguration(config.getSiteConfig());
+    cfg.setListDelimiter('\0');
+    return Collections.<AbstractConfiguration> singletonList(cfg);
   }
 
   @Override


[9/9] accumulo git commit: Merge branch '1.7'

Posted by el...@apache.org.
Merge branch '1.7'


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

Branch: refs/heads/master
Commit: 5fbd67157d05efa85b54cd350ef2a0f32302214d
Parents: f6bd3ee d71e5ee
Author: Josh Elser <el...@apache.org>
Authored: Mon Jun 1 15:40:07 2015 -0400
Committer: Josh Elser <el...@apache.org>
Committed: Mon Jun 1 15:40:07 2015 -0400

----------------------------------------------------------------------
 .../impl/MiniAccumuloClusterImpl.java           | 10 ++++++--
 .../security/handler/KerberosAuthenticator.java |  8 +++++--
 .../apache/accumulo/test/TableOperationsIT.java | 24 ++++++++++++++++----
 .../replication/MultiInstanceReplicationIT.java |  7 ++++++
 4 files changed, 41 insertions(+), 8 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/5fbd6715/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/MiniAccumuloClusterImpl.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/accumulo/blob/5fbd6715/test/src/test/java/org/apache/accumulo/test/replication/MultiInstanceReplicationIT.java
----------------------------------------------------------------------


[3/9] accumulo git commit: ACCUMULO-3879 Improved logging on MultiInstanceReplicationIT

Posted by el...@apache.org.
ACCUMULO-3879 Improved logging on MultiInstanceReplicationIT


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

Branch: refs/heads/1.7
Commit: a31ada5425c62a07195cf8148e60ed4735c1af57
Parents: c100231
Author: Josh Elser <el...@apache.org>
Authored: Mon Jun 1 14:41:36 2015 -0400
Committer: Josh Elser <el...@apache.org>
Committed: Mon Jun 1 14:44:20 2015 -0400

----------------------------------------------------------------------
 .../accumulo/test/replication/MultiInstanceReplicationIT.java | 7 +++++++
 1 file changed, 7 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/a31ada54/test/src/test/java/org/apache/accumulo/test/replication/MultiInstanceReplicationIT.java
----------------------------------------------------------------------
diff --git a/test/src/test/java/org/apache/accumulo/test/replication/MultiInstanceReplicationIT.java b/test/src/test/java/org/apache/accumulo/test/replication/MultiInstanceReplicationIT.java
index 7dd31c0..3dc029e 100644
--- a/test/src/test/java/org/apache/accumulo/test/replication/MultiInstanceReplicationIT.java
+++ b/test/src/test/java/org/apache/accumulo/test/replication/MultiInstanceReplicationIT.java
@@ -216,6 +216,8 @@ public class MultiInstanceReplicationIT extends ConfigurableMacIT {
 
       final Set<String> filesNeedingReplication = connMaster.replicationOperations().referencedFiles(masterTable);
 
+      log.info("Files to replicate: " + filesNeedingReplication);
+
       for (ProcessReference proc : cluster.getProcesses().get(ServerType.TABLET_SERVER)) {
         cluster.killProcess(ServerType.TABLET_SERVER, proc);
       }
@@ -403,6 +405,9 @@ public class MultiInstanceReplicationIT extends ConfigurableMacIT {
       Set<String> filesFor1 = connMaster.replicationOperations().referencedFiles(masterTable1), filesFor2 = connMaster.replicationOperations().referencedFiles(
           masterTable2);
 
+      log.info("Files to replicate for table1: " + filesFor1);
+      log.info("Files to replicate for table2: " + filesFor2);
+
       // Restart the tserver to force a close on the WAL
       for (ProcessReference proc : cluster.getProcesses().get(ServerType.TABLET_SERVER)) {
         cluster.killProcess(ServerType.TABLET_SERVER, proc);
@@ -520,6 +525,8 @@ public class MultiInstanceReplicationIT extends ConfigurableMacIT {
 
     Set<String> files = connMaster.replicationOperations().referencedFiles(masterTable);
 
+    log.info("Files to replicate:" + files);
+
     for (ProcessReference proc : cluster.getProcesses().get(ServerType.TABLET_SERVER)) {
       cluster.killProcess(ServerType.TABLET_SERVER, proc);
     }


[7/9] accumulo git commit: ACCUMULO-3874 base64 decode the principal before sending it back

Posted by el...@apache.org.
ACCUMULO-3874 base64 decode the principal before sending it back


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

Branch: refs/heads/master
Commit: d71e5ee4c3b331e9467769d177876b0b2859e978
Parents: acb5d2e
Author: Josh Elser <el...@apache.org>
Authored: Mon Jun 1 15:38:55 2015 -0400
Committer: Josh Elser <el...@apache.org>
Committed: Mon Jun 1 15:38:55 2015 -0400

----------------------------------------------------------------------
 .../server/security/handler/KerberosAuthenticator.java       | 8 ++++++--
 1 file changed, 6 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/d71e5ee4/server/base/src/main/java/org/apache/accumulo/server/security/handler/KerberosAuthenticator.java
----------------------------------------------------------------------
diff --git a/server/base/src/main/java/org/apache/accumulo/server/security/handler/KerberosAuthenticator.java b/server/base/src/main/java/org/apache/accumulo/server/security/handler/KerberosAuthenticator.java
index 4ec4ba4..3ead57f 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/security/handler/KerberosAuthenticator.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/security/handler/KerberosAuthenticator.java
@@ -171,8 +171,12 @@ public class KerberosAuthenticator implements Authenticator {
 
   @Override
   public synchronized void dropUser(String user) throws AccumuloSecurityException {
-    user = Base64.encodeBase64String(user.getBytes(UTF_8));
-    zkAuthenticator.dropUser(user);
+    final String encodedUser = Base64.encodeBase64String(user.getBytes(UTF_8));
+    try {
+      zkAuthenticator.dropUser(encodedUser);
+    } catch (AccumuloSecurityException e) {
+      throw new AccumuloSecurityException(user, e.asThriftException().getCode(), e.getCause());
+    }
   }
 
   @Override


[5/9] accumulo git commit: ACCUMULO-3878 Add a missing list delimiter

Posted by el...@apache.org.
ACCUMULO-3878 Add a missing list delimiter


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

Branch: refs/heads/1.7
Commit: acb5d2e2bed89db4d0b294e987cde18d1689fd12
Parents: a31ada5
Author: Josh Elser <el...@apache.org>
Authored: Mon Jun 1 14:47:54 2015 -0400
Committer: Josh Elser <el...@apache.org>
Committed: Mon Jun 1 15:38:46 2015 -0400

----------------------------------------------------------------------
 .../minicluster/impl/MiniAccumuloClusterImpl.java         | 10 ++++++++--
 1 file changed, 8 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/acb5d2e2/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/MiniAccumuloClusterImpl.java
----------------------------------------------------------------------
diff --git a/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/MiniAccumuloClusterImpl.java b/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/MiniAccumuloClusterImpl.java
index 2e631b8..5ca0429 100644
--- a/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/MiniAccumuloClusterImpl.java
+++ b/minicluster/src/main/java/org/apache/accumulo/minicluster/impl/MiniAccumuloClusterImpl.java
@@ -90,6 +90,7 @@ import org.apache.accumulo.server.util.time.SimpleTimer;
 import org.apache.accumulo.server.zookeeper.ZooReaderWriterFactory;
 import org.apache.accumulo.start.Main;
 import org.apache.accumulo.start.classloader.vfs.MiniDFSUtil;
+import org.apache.commons.configuration.AbstractConfiguration;
 import org.apache.commons.configuration.MapConfiguration;
 import org.apache.commons.io.FileUtils;
 import org.apache.commons.vfs2.FileObject;
@@ -728,8 +729,13 @@ public class MiniAccumuloClusterImpl implements AccumuloCluster {
 
   @Override
   public ClientConfiguration getClientConfig() {
-    return new ClientConfiguration(Arrays.asList(new MapConfiguration(config.getSiteConfig()))).withInstance(this.getInstanceName()).withZkHosts(
-        this.getZooKeepers());
+    return new ClientConfiguration(getConfigs(config)).withInstance(this.getInstanceName()).withZkHosts(this.getZooKeepers());
+  }
+
+  private static List<AbstractConfiguration> getConfigs(MiniAccumuloConfigImpl config) {
+    MapConfiguration cfg = new MapConfiguration(config.getSiteConfig());
+    cfg.setListDelimiter('\0');
+    return Collections.<AbstractConfiguration> singletonList(cfg);
   }
 
   @Override


[8/9] accumulo git commit: ACCUMULO-3874 base64 decode the principal before sending it back

Posted by el...@apache.org.
ACCUMULO-3874 base64 decode the principal before sending it back


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

Branch: refs/heads/1.7
Commit: d71e5ee4c3b331e9467769d177876b0b2859e978
Parents: acb5d2e
Author: Josh Elser <el...@apache.org>
Authored: Mon Jun 1 15:38:55 2015 -0400
Committer: Josh Elser <el...@apache.org>
Committed: Mon Jun 1 15:38:55 2015 -0400

----------------------------------------------------------------------
 .../server/security/handler/KerberosAuthenticator.java       | 8 ++++++--
 1 file changed, 6 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/d71e5ee4/server/base/src/main/java/org/apache/accumulo/server/security/handler/KerberosAuthenticator.java
----------------------------------------------------------------------
diff --git a/server/base/src/main/java/org/apache/accumulo/server/security/handler/KerberosAuthenticator.java b/server/base/src/main/java/org/apache/accumulo/server/security/handler/KerberosAuthenticator.java
index 4ec4ba4..3ead57f 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/security/handler/KerberosAuthenticator.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/security/handler/KerberosAuthenticator.java
@@ -171,8 +171,12 @@ public class KerberosAuthenticator implements Authenticator {
 
   @Override
   public synchronized void dropUser(String user) throws AccumuloSecurityException {
-    user = Base64.encodeBase64String(user.getBytes(UTF_8));
-    zkAuthenticator.dropUser(user);
+    final String encodedUser = Base64.encodeBase64String(user.getBytes(UTF_8));
+    try {
+      zkAuthenticator.dropUser(encodedUser);
+    } catch (AccumuloSecurityException e) {
+      throw new AccumuloSecurityException(user, e.asThriftException().getCode(), e.getCause());
+    }
   }
 
   @Override


[2/9] accumulo git commit: ACCUMULO-3877 Fix the test to acct for compactions over both tablets.

Posted by el...@apache.org.
ACCUMULO-3877 Fix the test to acct for compactions over both tablets.


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

Branch: refs/heads/master
Commit: c100231a644a20b48aaa8014aa6c41dfa0781ed3
Parents: 3289940
Author: Josh Elser <el...@apache.org>
Authored: Mon Jun 1 13:05:28 2015 -0400
Committer: Josh Elser <el...@apache.org>
Committed: Mon Jun 1 13:05:28 2015 -0400

----------------------------------------------------------------------
 .../apache/accumulo/test/TableOperationsIT.java | 24 ++++++++++++++++----
 1 file changed, 20 insertions(+), 4 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/c100231a/test/src/test/java/org/apache/accumulo/test/TableOperationsIT.java
----------------------------------------------------------------------
diff --git a/test/src/test/java/org/apache/accumulo/test/TableOperationsIT.java b/test/src/test/java/org/apache/accumulo/test/TableOperationsIT.java
index ced9d69..dc8f9dd 100644
--- a/test/src/test/java/org/apache/accumulo/test/TableOperationsIT.java
+++ b/test/src/test/java/org/apache/accumulo/test/TableOperationsIT.java
@@ -61,7 +61,6 @@ import org.apache.accumulo.test.functional.BadIterator;
 import org.apache.hadoop.io.Text;
 import org.apache.thrift.TException;
 import org.junit.Assert;
-import org.junit.Assume;
 import org.junit.Before;
 import org.junit.Test;
 
@@ -305,9 +304,26 @@ public class TableOperationsIT extends AccumuloClusterIT {
     Map<Key,Value> actual = new TreeMap<>(COMPARE_KEY_TO_COLQ); // only compare row, colF, colQ
     for (Map.Entry<Key,Value> entry : scanner)
       actual.put(entry.getKey(), entry.getValue());
-    Assume
-        .assumeFalse("Compaction successfully occurred due to weird timing but we hoped it would cancel.", HardListIterator.allEntriesToInject.equals(actual));
-    assertTrue("Scan should be empty if compaction canceled. " + "Actual is " + actual, actual.isEmpty());
+    switch (actual.size()) {
+      case 3:
+        // Compaction cancel didn't happen in time
+        assertTrue(HardListIterator.allEntriesToInject.equals(actual));
+        break;
+      case 2:
+        // Compacted the first tablet (-inf, f)
+        assertEquals(HardListIterator.allEntriesToInject.headMap(new Key("f")), actual);
+        break;
+      case 1:
+        // Compacted the second tablet [f, +inf)
+        assertEquals(HardListIterator.allEntriesToInject.tailMap(new Key("f")), actual);
+        break;
+      case 0:
+        // Cancelled the compaction before it ran. No generated entries.
+        break;
+      default:
+        Assert.fail("Unexpected number of entries");
+        break;
+    }
     connector.tableOperations().delete(tableName);
   }
 


[4/9] accumulo git commit: ACCUMULO-3879 Improved logging on MultiInstanceReplicationIT

Posted by el...@apache.org.
ACCUMULO-3879 Improved logging on MultiInstanceReplicationIT


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

Branch: refs/heads/master
Commit: a31ada5425c62a07195cf8148e60ed4735c1af57
Parents: c100231
Author: Josh Elser <el...@apache.org>
Authored: Mon Jun 1 14:41:36 2015 -0400
Committer: Josh Elser <el...@apache.org>
Committed: Mon Jun 1 14:44:20 2015 -0400

----------------------------------------------------------------------
 .../accumulo/test/replication/MultiInstanceReplicationIT.java | 7 +++++++
 1 file changed, 7 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/a31ada54/test/src/test/java/org/apache/accumulo/test/replication/MultiInstanceReplicationIT.java
----------------------------------------------------------------------
diff --git a/test/src/test/java/org/apache/accumulo/test/replication/MultiInstanceReplicationIT.java b/test/src/test/java/org/apache/accumulo/test/replication/MultiInstanceReplicationIT.java
index 7dd31c0..3dc029e 100644
--- a/test/src/test/java/org/apache/accumulo/test/replication/MultiInstanceReplicationIT.java
+++ b/test/src/test/java/org/apache/accumulo/test/replication/MultiInstanceReplicationIT.java
@@ -216,6 +216,8 @@ public class MultiInstanceReplicationIT extends ConfigurableMacIT {
 
       final Set<String> filesNeedingReplication = connMaster.replicationOperations().referencedFiles(masterTable);
 
+      log.info("Files to replicate: " + filesNeedingReplication);
+
       for (ProcessReference proc : cluster.getProcesses().get(ServerType.TABLET_SERVER)) {
         cluster.killProcess(ServerType.TABLET_SERVER, proc);
       }
@@ -403,6 +405,9 @@ public class MultiInstanceReplicationIT extends ConfigurableMacIT {
       Set<String> filesFor1 = connMaster.replicationOperations().referencedFiles(masterTable1), filesFor2 = connMaster.replicationOperations().referencedFiles(
           masterTable2);
 
+      log.info("Files to replicate for table1: " + filesFor1);
+      log.info("Files to replicate for table2: " + filesFor2);
+
       // Restart the tserver to force a close on the WAL
       for (ProcessReference proc : cluster.getProcesses().get(ServerType.TABLET_SERVER)) {
         cluster.killProcess(ServerType.TABLET_SERVER, proc);
@@ -520,6 +525,8 @@ public class MultiInstanceReplicationIT extends ConfigurableMacIT {
 
     Set<String> files = connMaster.replicationOperations().referencedFiles(masterTable);
 
+    log.info("Files to replicate:" + files);
+
     for (ProcessReference proc : cluster.getProcesses().get(ServerType.TABLET_SERVER)) {
       cluster.killProcess(ServerType.TABLET_SERVER, proc);
     }