You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@accumulo.apache.org by cj...@apache.org on 2015/01/23 04:10:41 UTC

[1/5] accumulo git commit: ACCUMULO-3505 Remove useExistingInstance(boolean) from MiniAccumuloConfig.

Repository: accumulo
Updated Branches:
  refs/heads/1.6.2-SNAPSHOT 981408a07 -> a2c8b7178 (forced update)


ACCUMULO-3505 Remove useExistingInstance(boolean) from MiniAccumuloConfig.

We can't make API additions in a patch release, so we need to remove this
from MAConfig. The feature is still usable via MAConfigImpl for 1.6.2.


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

Branch: refs/heads/1.6.2-SNAPSHOT
Commit: 2022d7c08dc21ec132992f8675b326795ebbaaa1
Parents: 00ba1a1
Author: Josh Elser <el...@apache.org>
Authored: Wed Jan 21 13:05:05 2015 -0500
Committer: Josh Elser <el...@apache.org>
Committed: Wed Jan 21 13:05:05 2015 -0500

----------------------------------------------------------------------
 .../accumulo/minicluster/MiniAccumuloConfig.java    | 16 ----------------
 .../org/apache/accumulo/test/ExistingMacIT.java     | 11 +++++------
 2 files changed, 5 insertions(+), 22 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/2022d7c0/minicluster/src/main/java/org/apache/accumulo/minicluster/MiniAccumuloConfig.java
----------------------------------------------------------------------
diff --git a/minicluster/src/main/java/org/apache/accumulo/minicluster/MiniAccumuloConfig.java b/minicluster/src/main/java/org/apache/accumulo/minicluster/MiniAccumuloConfig.java
index c8c499d..b71b771 100644
--- a/minicluster/src/main/java/org/apache/accumulo/minicluster/MiniAccumuloConfig.java
+++ b/minicluster/src/main/java/org/apache/accumulo/minicluster/MiniAccumuloConfig.java
@@ -17,7 +17,6 @@
 package org.apache.accumulo.minicluster;
 
 import java.io.File;
-import java.io.IOException;
 import java.util.Map;
 
 import org.apache.accumulo.minicluster.impl.MiniAccumuloConfigImpl;
@@ -252,19 +251,4 @@ public class MiniAccumuloConfig {
     impl.setNativeLibPaths(nativePathItems);
     return this;
   }
-
-  /**
-   * Informs MAC that it's running against an existing accumulo instance. It is assumed that it's already initialized and hdfs/zookeeper are already running.
-   *
-   * @param accumuloSite
-   *          a File representation of the accumulo-site.xml file for the instance being run
-   * @param hadoopConfDir
-   *          a File representation of the hadoop configuration directory containing core-site.xml and hdfs-site.xml
-   *
-   * @since 1.6.2
-   */
-  public MiniAccumuloConfig useExistingInstance(File accumuloSite, File hadoopConfDir) throws IOException {
-    impl.useExistingInstance(accumuloSite, hadoopConfDir);
-    return this;
-  }
 }

http://git-wip-us.apache.org/repos/asf/accumulo/blob/2022d7c0/test/src/test/java/org/apache/accumulo/test/ExistingMacIT.java
----------------------------------------------------------------------
diff --git a/test/src/test/java/org/apache/accumulo/test/ExistingMacIT.java b/test/src/test/java/org/apache/accumulo/test/ExistingMacIT.java
index df44feb..4acf302 100644
--- a/test/src/test/java/org/apache/accumulo/test/ExistingMacIT.java
+++ b/test/src/test/java/org/apache/accumulo/test/ExistingMacIT.java
@@ -37,9 +37,8 @@ import org.apache.accumulo.core.metadata.MetadataTable;
 import org.apache.accumulo.core.metadata.RootTable;
 import org.apache.accumulo.core.security.Authorizations;
 import org.apache.accumulo.core.util.UtilWaitThread;
-import org.apache.accumulo.minicluster.MiniAccumuloCluster;
-import org.apache.accumulo.minicluster.MiniAccumuloConfig;
 import org.apache.accumulo.minicluster.ServerType;
+import org.apache.accumulo.minicluster.impl.MiniAccumuloClusterImpl;
 import org.apache.accumulo.minicluster.impl.MiniAccumuloConfigImpl;
 import org.apache.accumulo.minicluster.impl.ProcessReference;
 import org.apache.accumulo.test.functional.ConfigurableMacIT;
@@ -111,10 +110,10 @@ public class ExistingMacIT extends ConfigurableMacIT {
     File testDir2 = createTestDir(ExistingMacIT.class.getSimpleName() + "_2");
     FileUtils.deleteQuietly(testDir2);
 
-    MiniAccumuloConfig macConfig2 = new MiniAccumuloConfig(testDir2, "notused");
+    MiniAccumuloConfigImpl macConfig2 = new MiniAccumuloConfigImpl(testDir2, "notused");
     macConfig2.useExistingInstance(new File(getCluster().getConfig().getConfDir(), "accumulo-site.xml"), hadoopConfDir);
 
-    MiniAccumuloCluster accumulo2 = new MiniAccumuloCluster(macConfig2);
+    MiniAccumuloClusterImpl accumulo2 = new MiniAccumuloClusterImpl(macConfig2);
     accumulo2.start();
 
     conn = accumulo2.getConnector("root", ROOT_PASSWORD);
@@ -152,12 +151,12 @@ public class ExistingMacIT extends ConfigurableMacIT {
     File testDir2 = createTestDir(ExistingMacIT.class.getSimpleName() + "_3");
     FileUtils.deleteQuietly(testDir2);
 
-    MiniAccumuloConfig macConfig2 = new MiniAccumuloConfig(testDir2, "notused");
+    MiniAccumuloConfigImpl macConfig2 = new MiniAccumuloConfigImpl(testDir2, "notused");
     macConfig2.useExistingInstance(new File(getCluster().getConfig().getConfDir(), "accumulo-site.xml"), hadoopConfDir);
 
     System.out.println("conf " + new File(getCluster().getConfig().getConfDir(), "accumulo-site.xml"));
 
-    MiniAccumuloCluster accumulo2 = new MiniAccumuloCluster(macConfig2);
+    MiniAccumuloClusterImpl accumulo2 = new MiniAccumuloClusterImpl(macConfig2);
     try {
       accumulo2.start();
       Assert.fail("A 2nd MAC instance should not be able to start over an existing MAC instance");


[4/5] accumulo git commit: ACCUMULO-3503 Remove extra space

Posted by cj...@apache.org.
ACCUMULO-3503 Remove extra space

Removes the extra space which was added, which was preventing a clean build (a
build in which no files in the source tree are modified).


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

Branch: refs/heads/1.6.2-SNAPSHOT
Commit: 67dd532d9bf02ec0e6bb8b96331344e34692cba9
Parents: 7ff6169
Author: Christopher Tubbs <ct...@apache.org>
Authored: Thu Jan 22 15:17:58 2015 -0500
Committer: Christopher Tubbs <ct...@apache.org>
Committed: Thu Jan 22 15:17:58 2015 -0500

----------------------------------------------------------------------
 trace/src/main/scripts/generate-thrift.sh | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/67dd532d/trace/src/main/scripts/generate-thrift.sh
----------------------------------------------------------------------
diff --git a/trace/src/main/scripts/generate-thrift.sh b/trace/src/main/scripts/generate-thrift.sh
index 96116f8..0bb0005 100755
--- a/trace/src/main/scripts/generate-thrift.sh
+++ b/trace/src/main/scripts/generate-thrift.sh
@@ -26,4 +26,4 @@ PACKAGES_TO_GENERATE=(trace)
 sed -i -e 's/\(public class TInfo .*\)$/\1\
 \
   private static final long serialVersionUID = -4659975753252858243l; \/\/ See ACCUMULO-3132\
- /' src/main/java/org/apache/accumulo/trace/thrift/TInfo.java
+/' src/main/java/org/apache/accumulo/trace/thrift/TInfo.java


[2/5] accumulo git commit: ACCUMULO-3504 Fix grammar/spelling errors in initialization output.

Posted by cj...@apache.org.
ACCUMULO-3504 Fix grammar/spelling errors in initialization output.


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

Branch: refs/heads/1.6.2-SNAPSHOT
Commit: 1df12a7b468bd27a917010df58f83833faec8849
Parents: 2022d7c
Author: Josh Elser <el...@apache.org>
Authored: Wed Jan 21 14:15:59 2015 -0500
Committer: Josh Elser <el...@apache.org>
Committed: Wed Jan 21 14:16:29 2015 -0500

----------------------------------------------------------------------
 .../base/src/main/java/org/apache/accumulo/server/Accumulo.java  | 4 ++--
 1 file changed, 2 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/1df12a7b/server/base/src/main/java/org/apache/accumulo/server/Accumulo.java
----------------------------------------------------------------------
diff --git a/server/base/src/main/java/org/apache/accumulo/server/Accumulo.java b/server/base/src/main/java/org/apache/accumulo/server/Accumulo.java
index 147a7c2..f78b28a 100644
--- a/server/base/src/main/java/org/apache/accumulo/server/Accumulo.java
+++ b/server/base/src/main/java/org/apache/accumulo/server/Accumulo.java
@@ -275,7 +275,7 @@ public class Accumulo {
         UtilWaitThread.sleep(1000);
       }
     }
-    log.info("Zookeeper connected and initialized, attemping to talk to HDFS");
+    log.info("ZooKeeper connected and initialized, attempting to talk to HDFS");
     long sleep = 1000;
     int unknownHostTries = 3;
     while (true) {
@@ -293,7 +293,7 @@ public class Accumulo {
             /* We need to make sure our sleep period is long enough to avoid getting a cached failure of the host lookup. */
             sleep = Math.max(sleep, (AddressUtil.getAddressCacheNegativeTtl((UnknownHostException) (exception.getCause())) + 1) * 1000);
           } else {
-            log.error("Unable to connect to HDFS and have exceeded max number of retries.", exception);
+            log.error("Unable to connect to HDFS and have exceeded the maximum number of retries.", exception);
             throw exception;
           }
           unknownHostTries--;


[5/5] accumulo git commit: ACCUMULO-3432 Updating CHANGES file to include all tickets completed for version 1.6.2

Posted by cj...@apache.org.
ACCUMULO-3432 Updating CHANGES file to include all tickets completed for version 1.6.2


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

Branch: refs/heads/1.6.2-SNAPSHOT
Commit: a2c8b7178044a7bf1618973e61c827d411e8090d
Parents: 67dd532
Author: Corey J. Nolet <cj...@gmail.com>
Authored: Thu Jan 22 22:09:27 2015 -0500
Committer: Corey J. Nolet <cj...@gmail.com>
Committed: Thu Jan 22 22:09:27 2015 -0500

----------------------------------------------------------------------
 CHANGES | 170 +++++++++++++++++++++++++++++++++++++++++++++++++++++++++++
 1 file changed, 170 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/a2c8b717/CHANGES
----------------------------------------------------------------------
diff --git a/CHANGES b/CHANGES
index 91b9d31..26bdc03 100644
--- a/CHANGES
+++ b/CHANGES
@@ -15,6 +15,176 @@
   limitations under the License.
 -->
 
+
+Release Notes - Accumulo - Version 1.6.2
+
+** Sub-task
+    * [ACCUMULO-1722] - add the ability to dump user permissions to the dumpConfig admin command
+    * [ACCUMULO-2981] - Cease use of underscore "_" as an identifier
+    * [ACCUMULO-3220] - Division by zero if encryption cipher isn't a block cipher
+    * [ACCUMULO-3221] - Unintential integer overflow in Shell authorization timeout
+    * [ACCUMULO-3223] - DefaultLoadBalancer allows a NPE just to catch it
+    * [ACCUMULO-3225] - Dead code in ConfigCommand
+    * [ACCUMULO-3226] - Unnecessary null check in Authorizations constructor
+    * [ACCUMULO-3228] - fix potential resource leaks
+    * [ACCUMULO-3278] - Mismatched arguments provided to Retry constructor in RetryFactory
+    * [ACCUMULO-3317] - Change Jetty configuration to disallow SSLv3
+    * [ACCUMULO-3318] - Alter Thrift RPC components to disallow SSLv3
+    * [ACCUMULO-3386] - Update release notes to explain how to correct data written with the buggy DateLexicoder
+    * [ACCUMULO-3401] - Remove internal use of deprecated test classes
+
+
+
+** Bug
+    * [ACCUMULO-2381] - AddFilesWithMissingEntries needs to just find abandoned files, or be deleted
+    * [ACCUMULO-2591] - TeraSortIngest should maintain binary compatibility between Hadoop 1 and Hadoop 2
+    * [ACCUMULO-2641] - scan id not set in org.apache.accumulo.core.client.admin.ActiveScan
+    * [ACCUMULO-2727] - version argument of ZooUtil.recursiveDelete is ignored
+    * [ACCUMULO-2793] - Clean up handling of moving HDFS under Accumulo from non-HA to HA
+    * [ACCUMULO-3002] - Handle instance.volumes in upgrade
+    * [ACCUMULO-3085] - Missing space in RootFiles log message
+    * [ACCUMULO-3111] - Race condition in MetaSplitIT
+    * [ACCUMULO-3126] - Malformed package-info.java
+    * [ACCUMULO-3135] - RW concurrent test failed with table doesn't exist exception
+    * [ACCUMULO-3157] - MetaDataTableScanner is unclosed upon return from FindOfflineTablets#findOffline()
+    * [ACCUMULO-3158] - FindOfflineTablets.close() causing compilation failure
+    * [ACCUMULO-3172] - mavanagaiata plugin marks releases "dirty"
+    * [ACCUMULO-3181] - VolumeChooser usage doesn't always comply with implied API contract
+    * [ACCUMULO-3182] - Empty or partial WAL header blocks successful recovery
+    * [ACCUMULO-3183] - Compaction strategy does not use per table classpath
+    * [ACCUMULO-3187] - ExamplesIT testScansWithInterference and testIsolatedScansWithInterference run out of heap
+    * [ACCUMULO-3189] - Compaction strategy plan is not validated
+    * [ACCUMULO-3190] - Fix use of deprecated instance.getConfiguration()
+    * [ACCUMULO-3194] - BulkSplitOptimizationIT failed with 5 files associated with tablet instead of 1-4 files
+    * [ACCUMULO-3213] - EOFException on metadata tablet during DeleteTableDuringSplitIT
+    * [ACCUMULO-3215] - Import tries to use default DFS directory instead of configured
+    * [ACCUMULO-3217] - KeyValue doesn't implement equals or hashCode
+    * [ACCUMULO-3218] - ZooKeeperInstance only uses first ZooKeeper in list of quorum
+    * [ACCUMULO-3229] - Shell displays authTimeout poorly
+    * [ACCUMULO-3230] - MR/Yarn job submission fails using `accumulo` with timeline client enabled
+    * [ACCUMULO-3242] - Consolidate ZK code WRT retries
+    * [ACCUMULO-3244] - bulk import report should include filenames
+    * [ACCUMULO-3255] - ExistingMacIT.testExistingRunningInstance failed because it started on top of an already running instance
+    * [ACCUMULO-3261] - Image Randomwalk fails if no rows are found
+    * [ACCUMULO-3264] - AuditMessageIT broken
+    * [ACCUMULO-3269] - nondeterministic failure of MiniAccumuloClusterStartStopTest
+    * [ACCUMULO-3280] - Initialize creates unnecessary directories
+    * [ACCUMULO-3286] - ConditionalWriterIT.testTrace failed
+    * [ACCUMULO-3289] - BulkFileIT failed to import files
+    * [ACCUMULO-3290] - ShellServerIT#listscans fails if scan shows up a QUEUED
+    * [ACCUMULO-3291] - MiniAccumuloClusterStartStopTest uses /tmp instead of target/
+    * [ACCUMULO-3292] - ConditionalWriterIT#testOffline failed
+    * [ACCUMULO-3296] - ZooUtil.recursiveDelete looping indefinitely
+    * [ACCUMULO-3297] - FileManager semaphore acquisition may block Root and Metadata scans
+    * [ACCUMULO-3298] - ConditionalMutationSet.DuplicateFitler is misspelled 
+    * [ACCUMULO-3301] - TableOperationsImpl.waitForTableStateTransition(String, TableState) never fetches `future` column
+    * [ACCUMULO-3305] - MiniAccumuloClusterImpl#killProcess should use the stopWithTimeout method
+    * [ACCUMULO-3312] - IllegalArgumentException in master and gc during randomwalk
+    * [ACCUMULO-3314] - RewriteTabletDirectoriesIT failed
+    * [ACCUMULO-3323] - Bad formatting in continuous ingest readme
+    * [ACCUMULO-3332] - CloudStone tests fail with "NameError: global name 'accumuloConf' is not defined"
+    * [ACCUMULO-3333] - Cloudstone1 doesn't pass in username/password to shell
+    * [ACCUMULO-3334] - CloudStone4 doesn't provide arguments correctly to TeraSortIngest
+    * [ACCUMULO-3340] - MiniAccumuloCluster takes a long time to start when IPv6 is enabled
+    * [ACCUMULO-3341] - `deletetable -p` should never match a table in the accumulo namespace
+    * [ACCUMULO-3351] - Tracer can't write traces after offline and online of trace table
+    * [ACCUMULO-3352] - Confusing BulkImport error message
+    * [ACCUMULO-3355] - TraceDump.printStackTrace prints Long.MAX_VALUE as a date when trace is not found
+    * [ACCUMULO-3358] - Thread in ReadWriteIT.interleaveTest is never started
+    * [ACCUMULO-3362] - Incorrect javadoc on StatsCombiner
+    * [ACCUMULO-3365] - TraceServer dies if trace table is offline during constructor
+    * [ACCUMULO-3372] - deadlock in tserver
+    * [ACCUMULO-3377] - BulkImporter.getAssignments provides unhelpful exception with bad file permissions
+    * [ACCUMULO-3383] - AccumuloVFSClassloader creates conflicting local cache directory names when vfs.cache.dir property is set.
+    * [ACCUMULO-3385] - DateLexicoder fails to correctly order dates prior to 1970
+    * [ACCUMULO-3392] - Incorrect javadoc on MiniAccumuloCluster.start
+    * [ACCUMULO-3397] - CANDIDATE_MEMORY_PERCENTAGE is too low
+    * [ACCUMULO-3406] - IllegalArgumentException during file GC
+    * [ACCUMULO-3407] - scan page in monitor is causing the monitor to crash w/OOM
+    * [ACCUMULO-3408] - display the exact number of tablet servers
+    * [ACCUMULO-3419] - Some ExamplesIT tests repeatedly failing
+    * [ACCUMULO-3424] - Token class option always requires token property
+    * [ACCUMULO-3435] - Sporadic MetadataMaxFilesIT failure
+    * [ACCUMULO-3438] - Shell TokenConverter fails silently
+    * [ACCUMULO-3441] - Master stuck attempting to assign root tablet to previous session of tserver
+    * [ACCUMULO-3443] - DfsLogger doesn't specify charset when reading header bytes
+    * [ACCUMULO-3445] - Server failure to login using Kerberos doesn't exit the process
+    * [ACCUMULO-3446] - Move SecurityUtil out of core
+    * [ACCUMULO-3448] - ZooUtil throws exception even when retry succeeds
+    * [ACCUMULO-3450] - Example logging configs should disable audit log to application log files
+    * [ACCUMULO-3462] - tablet not major compacting
+    * [ACCUMULO-3468] - MonitorUtil's zookeeper timeout is a little low
+    * [ACCUMULO-3472] - VolumeImpl.isValidPath not working as intended
+    * [ACCUMULO-3474] - ProxyServer ignores value of isDeleted on ColumnUpdate
+    * [ACCUMULO-3475] - Shell.config()'s return value is ignored.
+    * [ACCUMULO-3481] - boolean not updated when native maps loaded from System.loadLibrary
+    * [ACCUMULO-3496] - ZooKeeperInstance doesn't validate instance name on creation
+    * [ACCUMULO-3503] - generate_thrift.sh search and replace for TInfo.java is not working on Mac
+    * [ACCUMULO-3504] - Typo in startup message
+
+
+
+
+** Improvement
+    * [ACCUMULO-2290] - documentation should describe how to stop / start individual nodes
+    * [ACCUMULO-2826] - IntersectingIterator should allow a single column family
+    * [ACCUMULO-2984] - Enable running MAC using an existing instance
+    * [ACCUMULO-3160] - ExamplesIT usage of MAC is sub-par
+    * [ACCUMULO-3167] - Decouple MiniAccumuloCluster from integration test base class
+    * [ACCUMULO-3175] - More IT stabilizations
+    * [ACCUMULO-3188] - DfsLogger has inefficient seek in crypto case
+    * [ACCUMULO-3192] - Improve 'fate print' to support the '-np' argument
+    * [ACCUMULO-3212] - Configuration objects created with CredentialProvider load defaults unnecessarily
+    * [ACCUMULO-3224] - Shell should use nanos for auth timeout
+    * [ACCUMULO-3233] - Random port for ZK in MiniAccumulo might not be unique
+    * [ACCUMULO-3237] - generate-thrift.sh should check for 0.9.1, not just 0.9
+    * [ACCUMULO-3257] - Make Randomwalk respect timeout (maxSec) more reliably
+    * [ACCUMULO-3258] - Warning about synconclose is way too spammy
+    * [ACCUMULO-3259] - Randomwalk Bulk.xml create queued threads without bound.
+    * [ACCUMULO-3263] - re-write tablet directories to fairly use multiple name-nodes
+    * [ACCUMULO-3265] - Describe bootstrap_config.sh in README
+    * [ACCUMULO-3271] - Add splits to tables in MultiTable randomwalk module
+    * [ACCUMULO-3275] - "not balancing because of unhosted tablets" message should include number of unhosted tablets
+    * [ACCUMULO-3300] - monitor ingest, query, etc. rates are too smooth
+    * [ACCUMULO-3304] - Add introspection of long running assignments
+    * [ACCUMULO-3308] - Add section to "11.5. Configuration" to IMM and WAL configuration values
+    * [ACCUMULO-3315] - Explicitly wait for threadpool shutdown in RandomizeVolumes
+    * [ACCUMULO-3337] - Assorted test stabilizations from external test runs
+    * [ACCUMULO-3338] - Update example classpath configuration
+    * [ACCUMULO-3347] - Improve logging for cancelled scans
+    * [ACCUMULO-3395] - Keep a reference to Logger in RpcWrapper
+    * [ACCUMULO-3436] - User manual doesn't have any discussion about FATE
+    * [ACCUMULO-3440] - TabletGroupWatcher tablet assigning logging is excessive
+    * [ACCUMULO-3466] - Range.mergeOverlapping(Collection) should have short-circuit for collections with only one item
+
+
+
+
+
+
+
+
+
+** Task
+    * [ACCUMULO-2997] - Confusing race condition comment in resizing of TServer client pool
+    * [ACCUMULO-3203] - Remove unused, undocumented SecretKeyEncryptionStrategyContext
+    * [ACCUMULO-3205] - JCEKS files sometimes aren't detected as binary; they should be excluded from RAT.
+    * [ACCUMULO-3243] - Ensure all ITs have some timeout
+    * [ACCUMULO-3288] - Use static import for UTF-8
+    * [ACCUMULO-3316] - Update TLS usage to mitigate POODLE
+    * [ACCUMULO-3400] - VolumeManager should validate the choice that a VolumeChooser makes
+    * [ACCUMULO-3405] - Update findbugs maven plugin
+    * [ACCUMULO-3433] - Lack of consistent serialversionid causing TraceRepoDeserializationTest to fail
+    * [ACCUMULO-3451] - Enforce some minimal style checks in the build
+    * [ACCUMULO-3476] - Better documentation on configuring Accumulo for SSL in user manual
+    * [ACCUMULO-3505] - Remove existingInstance from MiniAccumuloConfig
+
+
+** Test
+    * [ACCUMULO-3207] - SimpleBalancerFairnessIT fails
+
+
+
 Release Notes - Accumulo - Version 1.6.1
 
 


[3/5] accumulo git commit: ACCUMULO-3505 Remove deprecated code usage

Posted by cj...@apache.org.
ACCUMULO-3505 Remove deprecated code usage


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

Branch: refs/heads/1.6.2-SNAPSHOT
Commit: 7ff6169288ed41db3f990547adfeea234586c6b1
Parents: 1df12a7
Author: Christopher Tubbs <ct...@apache.org>
Authored: Wed Jan 21 18:02:08 2015 -0500
Committer: Christopher Tubbs <ct...@apache.org>
Committed: Wed Jan 21 18:02:08 2015 -0500

----------------------------------------------------------------------
 test/src/test/java/org/apache/accumulo/test/ExistingMacIT.java | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/accumulo/blob/7ff61692/test/src/test/java/org/apache/accumulo/test/ExistingMacIT.java
----------------------------------------------------------------------
diff --git a/test/src/test/java/org/apache/accumulo/test/ExistingMacIT.java b/test/src/test/java/org/apache/accumulo/test/ExistingMacIT.java
index 4acf302..6330a59 100644
--- a/test/src/test/java/org/apache/accumulo/test/ExistingMacIT.java
+++ b/test/src/test/java/org/apache/accumulo/test/ExistingMacIT.java
@@ -116,7 +116,7 @@ public class ExistingMacIT extends ConfigurableMacIT {
     MiniAccumuloClusterImpl accumulo2 = new MiniAccumuloClusterImpl(macConfig2);
     accumulo2.start();
 
-    conn = accumulo2.getConnector("root", ROOT_PASSWORD);
+    conn = accumulo2.getConnector("root", new PasswordToken(ROOT_PASSWORD));
 
     Scanner scanner = conn.createScanner("table1", Authorizations.EMPTY);