You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hbase.apache.org by st...@apache.org on 2014/10/14 17:52:24 UTC

[1/2] git commit: HBASE-12147 Porting Online Config Change from 89-fb -- JAVADOC FIX ADDENDUM -- REVERT

Repository: hbase
Updated Branches:
  refs/heads/branch-1 785d2fad2 -> 2822a289f


HBASE-12147 Porting Online Config Change from 89-fb -- JAVADOC FIX ADDENDUM -- REVERT


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

Branch: refs/heads/branch-1
Commit: 0ebb98d7b38337d226d1d210204c965acddf93be
Parents: 785d2fa
Author: stack <st...@apache.org>
Authored: Tue Oct 14 08:49:08 2014 -0700
Committer: stack <st...@apache.org>
Committed: Tue Oct 14 08:49:08 2014 -0700

----------------------------------------------------------------------
 .../main/java/org/apache/hadoop/hbase/client/MetaScanner.java    | 4 ++--
 1 file changed, 2 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/hbase/blob/0ebb98d7/hbase-client/src/main/java/org/apache/hadoop/hbase/client/MetaScanner.java
----------------------------------------------------------------------
diff --git a/hbase-client/src/main/java/org/apache/hadoop/hbase/client/MetaScanner.java b/hbase-client/src/main/java/org/apache/hadoop/hbase/client/MetaScanner.java
index ede542a..8013930 100644
--- a/hbase-client/src/main/java/org/apache/hadoop/hbase/client/MetaScanner.java
+++ b/hbase-client/src/main/java/org/apache/hadoop/hbase/client/MetaScanner.java
@@ -291,8 +291,8 @@ public class MetaScanner {
   /**
    * Lists all of the table regions currently in META.
    * @param conf
-   * @param connection
-   * @param tableName
+   * @param offlined True if we are to include offlined regions, false and we'll
+   * leave out offlined regions from returned list.
    * @return Map of all user-space regions to servers
    * @throws IOException
    */


[2/2] git commit: HBASE-12147 Porting Online Config Change from 89-fb -- REVERT

Posted by st...@apache.org.
HBASE-12147 Porting Online Config Change from 89-fb -- REVERT


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

Branch: refs/heads/branch-1
Commit: 2822a289f9bd59156fb5ea8305da26944fe5152e
Parents: 0ebb98d
Author: stack <st...@apache.org>
Authored: Tue Oct 14 08:51:37 2014 -0700
Committer: stack <st...@apache.org>
Committed: Tue Oct 14 08:51:37 2014 -0700

----------------------------------------------------------------------
 .../hadoop/hbase/conf/ConfigurationManager.java | 139 -------------
 .../hbase/conf/ConfigurationObserver.java       |  38 ----
 .../conf/PropagatingConfigurationObserver.java  |  43 ----
 .../hbase/regionserver/CompactSplitThread.java  | 112 +---------
 .../hadoop/hbase/regionserver/HRegion.java      |  39 +---
 .../hbase/regionserver/HRegionServer.java       |  24 ---
 .../hadoop/hbase/regionserver/HStore.java       |  46 +----
 .../apache/hadoop/hbase/regionserver/Store.java |   4 +-
 .../compactions/CompactionConfiguration.java    |  48 +++--
 .../compactions/CompactionPolicy.java           |   8 +-
 .../regionserver/compactions/OffPeakHours.java  |   4 +-
 .../hbase/conf/TestConfigurationManager.java    | 133 ------------
 .../TestRegionServerOnlineConfigChange.java     | 206 -------------------
 .../compactions/TestOffPeakHours.java           |   8 +-
 14 files changed, 41 insertions(+), 811 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/hbase/blob/2822a289/hbase-server/src/main/java/org/apache/hadoop/hbase/conf/ConfigurationManager.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/main/java/org/apache/hadoop/hbase/conf/ConfigurationManager.java b/hbase-server/src/main/java/org/apache/hadoop/hbase/conf/ConfigurationManager.java
deleted file mode 100644
index 76edbf4..0000000
--- a/hbase-server/src/main/java/org/apache/hadoop/hbase/conf/ConfigurationManager.java
+++ /dev/null
@@ -1,139 +0,0 @@
-/**
- * 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.hadoop.hbase.conf;
-
-import org.apache.commons.logging.Log;
-import org.apache.commons.logging.LogFactory;
-import org.apache.hadoop.conf.Configuration;
-import org.apache.hadoop.hbase.classification.InterfaceAudience;
-import org.apache.hadoop.hbase.classification.InterfaceStability;
-
-import java.util.Collections;
-import java.util.Set;
-import java.util.WeakHashMap;
-
-/**
- * Maintains the set of all the classes which would like to get notified
- * when the Configuration is reloaded from the disk in the Online Configuration
- * Change mechanism, which lets you update certain configuration properties
- * on-the-fly, without having to restart the cluster.
- *
- * If a class has configuration properties which you would like to be able to
- * change on-the-fly, do the following:
- * 1. Implement the {@link ConfigurationObserver} interface. This would require
- *    you to implement the
- *    {@link ConfigurationObserver#onConfigurationChange(Configuration)}
- *    method.  This is a callback that is used to notify your class' instance
- *    that the configuration has changed. In this method, you need to check
- *    if the new values for the properties that are of interest to your class
- *    are different from the cached values. If yes, update them.
- *
- *    However, be careful with this. Certain properties might be trivially
- *    mutable online, but others might not. Two properties might be trivially
- *    mutable by themselves, but not when changed together. For example, if a
- *    method uses properties "a" and "b" to make some decision, and is running
- *    in parallel when the notifyOnChange() method updates "a", but hasn't
- *    yet updated "b", it might make a decision on the basis of a new value of
- *    "a", and an old value of "b". This might introduce subtle bugs. This
- *    needs to be dealt on a case-by-case basis, and this class does not provide
- *    any protection from such cases.
- *
- * 2. Register the appropriate instance of the class with the
- *    {@link ConfigurationManager} instance, using the
- *    {@link ConfigurationManager#registerObserver(ConfigurationObserver)}
- *    method. For the RS side of things, the ConfigurationManager is a static
- *    member of the {@link org.apache.hadoop.hbase.regionserver.HRegionServer}
- *    class. Be careful not to do this in the constructor, as you might cause
- *    the 'this' reference to escape. Use a factory method, or an initialize()
- *    method which is called after the construction of the object.
- *
- * 3. Deregister the instance using the
- *    {@link ConfigurationManager#deregisterObserver(ConfigurationObserver)}
- *    method when it is going out of scope. In case you are not able to do that
- *    for any reason, it is still okay, since entries for dead observers are
- *    automatically collected during GC. But nonetheless, it is still a good
- *    practice to deregister your observer, whenever possible.
- *
- */
-@InterfaceAudience.Private
-@InterfaceStability.Evolving
-public class ConfigurationManager {
-  public static final Log LOG = LogFactory.getLog(ConfigurationManager.class);
-
-  // The set of Configuration Observers. These classes would like to get
-  // notified when the configuration is reloaded from disk. This is a set
-  // constructed from a WeakHashMap, whose entries would be removed if the
-  // observer classes go out of scope.
-  private Set<ConfigurationObserver> configurationObservers =
-    Collections.newSetFromMap(new WeakHashMap<ConfigurationObserver,
-                                              Boolean>());
-
-  /**
-   * Register an observer class
-   * @param observer
-   */
-  public void registerObserver(ConfigurationObserver observer) {
-    synchronized (configurationObservers) {
-      configurationObservers.add(observer);
-      if (observer instanceof PropagatingConfigurationObserver) {
-        ((PropagatingConfigurationObserver) observer).registerChildren(this);
-      }
-    }
-  }
-
-  /**
-   * Deregister an observer class
-   * @param observer
-   */
-  public void deregisterObserver(ConfigurationObserver observer) {
-    synchronized (configurationObservers) {
-      configurationObservers.remove(observer);
-      if (observer instanceof PropagatingConfigurationObserver) {
-        ((PropagatingConfigurationObserver) observer).deregisterChildren(this);
-      }
-    }
-  }
-
-  /**
-   * The conf object has been repopulated from disk, and we have to notify
-   * all the observers that are expressed interest to do that.
-   */
-  public void notifyAllObservers(Configuration conf) {
-    synchronized (configurationObservers) {
-      for (ConfigurationObserver observer : configurationObservers) {
-        try {
-          if (observer != null) {
-            observer.onConfigurationChange(conf);
-          }
-        } catch (Throwable t) {
-          LOG.error("Encountered a throwable while notifying observers: " + " of type : " +
-              observer.getClass().getCanonicalName() + "(" + observer + ")", t);
-        }
-      }
-    }
-  }
-
-  /**
-   * @return the number of observers. 
-   */
-  public int getNumObservers() {
-    synchronized (configurationObservers) {
-      return configurationObservers.size();
-    }
-  }
-}

http://git-wip-us.apache.org/repos/asf/hbase/blob/2822a289/hbase-server/src/main/java/org/apache/hadoop/hbase/conf/ConfigurationObserver.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/main/java/org/apache/hadoop/hbase/conf/ConfigurationObserver.java b/hbase-server/src/main/java/org/apache/hadoop/hbase/conf/ConfigurationObserver.java
deleted file mode 100644
index 211e371..0000000
--- a/hbase-server/src/main/java/org/apache/hadoop/hbase/conf/ConfigurationObserver.java
+++ /dev/null
@@ -1,38 +0,0 @@
-/**
- * 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.hadoop.hbase.conf;
-
-import org.apache.hadoop.conf.Configuration;
-import org.apache.hadoop.hbase.classification.InterfaceAudience;
-import org.apache.hadoop.hbase.classification.InterfaceStability;
-
-/**
- * Every class that wants to observe changes in Configuration properties,
- * must implement interface (and also, register itself with the
- * <code>ConfigurationManager</code> object.
- */
-@InterfaceAudience.Private
-@InterfaceStability.Evolving
-public interface ConfigurationObserver {
-
-  /**
-   * This method would be called by the {@link ConfigurationManager}
-   * object when the {@link Configuration} object is reloaded from disk.
-   */
-  void onConfigurationChange(Configuration conf);
-}

http://git-wip-us.apache.org/repos/asf/hbase/blob/2822a289/hbase-server/src/main/java/org/apache/hadoop/hbase/conf/PropagatingConfigurationObserver.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/main/java/org/apache/hadoop/hbase/conf/PropagatingConfigurationObserver.java b/hbase-server/src/main/java/org/apache/hadoop/hbase/conf/PropagatingConfigurationObserver.java
deleted file mode 100644
index 6ed2c77..0000000
--- a/hbase-server/src/main/java/org/apache/hadoop/hbase/conf/PropagatingConfigurationObserver.java
+++ /dev/null
@@ -1,43 +0,0 @@
-/**
- *
- * 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.hadoop.hbase.conf;
-
-import org.apache.hadoop.hbase.classification.InterfaceAudience;
-
-/**
- * This extension to ConfigurationObserver allows the configuration to propagate to the children of
- * the current {@link ConfigurationObserver}. This is the preferred way to make a class online
- * configurable because it allows the user to configure the children in a recursive manner
- * automatically. 
- */
-@InterfaceAudience.Private
-public interface PropagatingConfigurationObserver extends ConfigurationObserver {
-
-  /**
-   * Needs to be called to register the children to the manager. 
-   * @param manager : to register to
-   */
-  void registerChildren(ConfigurationManager manager);
-
-  /**
-   * Needs to be called to deregister the children from the manager. 
-   * @param manager : to deregister from
-   */
-  void deregisterChildren(ConfigurationManager manager);
-}

http://git-wip-us.apache.org/repos/asf/hbase/blob/2822a289/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/CompactSplitThread.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/CompactSplitThread.java b/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/CompactSplitThread.java
index 1badd39..f9e7b32 100644
--- a/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/CompactSplitThread.java
+++ b/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/CompactSplitThread.java
@@ -36,8 +36,6 @@ import java.util.concurrent.TimeUnit;
 import org.apache.commons.logging.Log;
 import org.apache.commons.logging.LogFactory;
 import org.apache.hadoop.hbase.classification.InterfaceAudience;
-import org.apache.hadoop.hbase.conf.ConfigurationManager;
-import org.apache.hadoop.hbase.conf.PropagatingConfigurationObserver;
 import org.apache.hadoop.conf.Configuration;
 import org.apache.hadoop.hbase.RemoteExceptionHandler;
 import org.apache.hadoop.hbase.regionserver.compactions.CompactionContext;
@@ -52,27 +50,9 @@ import com.google.common.base.Preconditions;
  * Compact region on request and then run split if appropriate
  */
 @InterfaceAudience.Private
-public class CompactSplitThread implements CompactionRequestor, PropagatingConfigurationObserver {
+public class CompactSplitThread implements CompactionRequestor {
   static final Log LOG = LogFactory.getLog(CompactSplitThread.class);
 
-  // Configuration key for the large compaction threads.
-  public final static String LARGE_COMPACTION_THREADS =
-      "hbase.regionserver.thread.compaction.large";
-  public final static int LARGE_COMPACTION_THREADS_DEFAULT = 1;
-  
-  // Configuration key for the small compaction threads.
-  public final static String SMALL_COMPACTION_THREADS =
-      "hbase.regionserver.thread.compaction.small";
-  public final static int SMALL_COMPACTION_THREADS_DEFAULT = 1;
-  
-  // Configuration key for split threads
-  public final static String SPLIT_THREADS = "hbase.regionserver.thread.split";
-  public final static int SPLIT_THREADS_DEFAULT = 1;
-  
-  // Configuration keys for merge threads
-  public final static String MERGE_THREADS = "hbase.regionserver.thread.merge";
-  public final static int MERGE_THREADS_DEFAULT = 1;
-  
   private final HRegionServer server;
   private final Configuration conf;
 
@@ -97,11 +77,11 @@ public class CompactSplitThread implements CompactionRequestor, PropagatingConfi
         Integer.MAX_VALUE);
 
     int largeThreads = Math.max(1, conf.getInt(
-        LARGE_COMPACTION_THREADS, LARGE_COMPACTION_THREADS_DEFAULT));
+        "hbase.regionserver.thread.compaction.large", 1));
     int smallThreads = conf.getInt(
-        SMALL_COMPACTION_THREADS, SMALL_COMPACTION_THREADS_DEFAULT);
+        "hbase.regionserver.thread.compaction.small", 1);
 
-    int splitThreads = conf.getInt(SPLIT_THREADS, SPLIT_THREADS_DEFAULT);
+    int splitThreads = conf.getInt("hbase.regionserver.thread.split", 1);
 
     // if we have throttle threads, make sure the user also specified size
     Preconditions.checkArgument(largeThreads > 0 && smallThreads > 0);
@@ -141,7 +121,7 @@ public class CompactSplitThread implements CompactionRequestor, PropagatingConfi
             return t;
           }
       });
-    int mergeThreads = conf.getInt(MERGE_THREADS, MERGE_THREADS_DEFAULT);
+    int mergeThreads = conf.getInt("hbase.regionserver.thread.merge", 1);
     this.mergePool = (ThreadPoolExecutor) Executors.newFixedThreadPool(
         mergeThreads, new ThreadFactory() {
           @Override
@@ -167,7 +147,7 @@ public class CompactSplitThread implements CompactionRequestor, PropagatingConfi
     queueLists.append("Compaction/Split Queue dump:\n");
     queueLists.append("  LargeCompation Queue:\n");
     BlockingQueue<Runnable> lq = longCompactions.getQueue();
-    Iterator<Runnable> it = lq.iterator();
+    Iterator it = lq.iterator();
     while(it.hasNext()){
       queueLists.append("    "+it.next().toString());
       queueLists.append("\n");
@@ -559,84 +539,4 @@ public class CompactSplitThread implements CompactionRequestor, PropagatingConfi
       }
     }
   }
-
-  /**
-   * {@inheritDoc}
-   */
-  @Override
-  public void onConfigurationChange(Configuration newConf) {
-    // Check if number of large / small compaction threads has changed, and then
-    // adjust the core pool size of the thread pools, by using the
-    // setCorePoolSize() method. According to the javadocs, it is safe to
-    // change the core pool size on-the-fly. We need to reset the maximum
-    // pool size, as well.
-    int largeThreads = Math.max(1, newConf.getInt(
-            LARGE_COMPACTION_THREADS,
-            LARGE_COMPACTION_THREADS_DEFAULT));
-    if (this.longCompactions.getCorePoolSize() != largeThreads) {
-      LOG.info("Changing the value of " + LARGE_COMPACTION_THREADS +
-              " from " + this.longCompactions.getCorePoolSize() + " to " +
-              largeThreads);
-      this.longCompactions.setMaximumPoolSize(largeThreads);
-      this.longCompactions.setCorePoolSize(largeThreads);
-    }
-
-    int smallThreads = newConf.getInt(SMALL_COMPACTION_THREADS,
-            SMALL_COMPACTION_THREADS_DEFAULT);
-    if (this.shortCompactions.getCorePoolSize() != smallThreads) {
-      LOG.info("Changing the value of " + SMALL_COMPACTION_THREADS +
-                " from " + this.shortCompactions.getCorePoolSize() + " to " +
-                smallThreads);
-      this.shortCompactions.setMaximumPoolSize(smallThreads);
-      this.shortCompactions.setCorePoolSize(smallThreads);
-    }
-
-    int splitThreads = newConf.getInt(SPLIT_THREADS,
-            SPLIT_THREADS_DEFAULT);
-    if (this.splits.getCorePoolSize() != splitThreads) {
-      LOG.info("Changing the value of " + SPLIT_THREADS +
-                " from " + this.splits.getCorePoolSize() + " to " +
-                splitThreads);
-      this.splits.setMaximumPoolSize(smallThreads);
-      this.splits.setCorePoolSize(smallThreads);
-    }
-
-    int mergeThreads = newConf.getInt(MERGE_THREADS,
-            MERGE_THREADS_DEFAULT);
-    if (this.mergePool.getCorePoolSize() != mergeThreads) {
-      LOG.info("Changing the value of " + MERGE_THREADS +
-                " from " + this.mergePool.getCorePoolSize() + " to " +
-                mergeThreads);
-      this.mergePool.setMaximumPoolSize(smallThreads);
-      this.mergePool.setCorePoolSize(smallThreads);
-    }
-
-    // We change this atomically here instead of reloading the config in order that upstream
-    // would be the only one with the flexibility to reload the config.
-    this.conf.reloadConfiguration();
-  }
-
-  protected int getSmallCompactionThreadNum() {
-    return this.shortCompactions.getCorePoolSize();
-  }
-
-  public int getLargeCompactionThreadNum() {
-    return this.longCompactions.getCorePoolSize();
-  }
-
-  /**
-   * {@inheritDoc}
-   */
-  @Override
-  public void registerChildren(ConfigurationManager manager) {
-    // No children to register.
-  }
-
-  /**
-   * {@inheritDoc}
-   */
-  @Override
-  public void deregisterChildren(ConfigurationManager manager) {
-    // No children to register
-  }
 }

http://git-wip-us.apache.org/repos/asf/hbase/blob/2822a289/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/HRegion.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/HRegion.java b/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/HRegion.java
index e00b7fe..14bc4bf 100644
--- a/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/HRegion.java
+++ b/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/HRegion.java
@@ -97,8 +97,6 @@ import org.apache.hadoop.hbase.client.Put;
 import org.apache.hadoop.hbase.client.Result;
 import org.apache.hadoop.hbase.client.RowMutations;
 import org.apache.hadoop.hbase.client.Scan;
-import org.apache.hadoop.hbase.conf.ConfigurationManager;
-import org.apache.hadoop.hbase.conf.PropagatingConfigurationObserver;
 import org.apache.hadoop.hbase.coprocessor.RegionObserver;
 import org.apache.hadoop.hbase.errorhandling.ForeignExceptionSnare;
 import org.apache.hadoop.hbase.exceptions.FailedSanityCheckException;
@@ -151,7 +149,6 @@ import org.apache.hadoop.io.MultipleIOException;
 import org.apache.hadoop.util.StringUtils;
 
 import com.google.common.annotations.VisibleForTesting;
-import com.google.common.base.Optional;
 import com.google.common.base.Preconditions;
 import com.google.common.collect.Lists;
 import com.google.common.collect.Maps;
@@ -199,7 +196,7 @@ import com.google.protobuf.Service;
  * defines the keyspace for this HRegion.
  */
 @InterfaceAudience.Private
-public class HRegion implements HeapSize, PropagatingConfigurationObserver { // , Writable{
+public class HRegion implements HeapSize { // , Writable{
   public static final Log LOG = LogFactory.getLog(HRegion.class);
 
   public static final String LOAD_CFS_ON_DEMAND_CONFIG_KEY =
@@ -350,8 +347,6 @@ public class HRegion implements HeapSize, PropagatingConfigurationObserver { //
   // when a region is in recovering state, it can only accept writes not reads
   private volatile boolean isRecovering = false;
 
-  private volatile Optional<ConfigurationManager> configurationManager;
-
   /**
    * @return The smallest mvcc readPoint across all the scanners in this
    * region. Writes older than this readPoint, are included  in every
@@ -670,7 +665,6 @@ public class HRegion implements HeapSize, PropagatingConfigurationObserver { //
     this.disallowWritesInRecovering =
         conf.getBoolean(HConstants.DISALLOW_WRITES_IN_RECOVERING,
           HConstants.DEFAULT_DISALLOW_WRITES_IN_RECOVERING_CONFIG);
-    configurationManager = Optional.absent();
   }
 
   void setHTableSpecificConf() {
@@ -5759,7 +5753,7 @@ public class HRegion implements HeapSize, PropagatingConfigurationObserver { //
   public static final long FIXED_OVERHEAD = ClassSize.align(
       ClassSize.OBJECT +
       ClassSize.ARRAY +
-      41 * ClassSize.REFERENCE + 2 * Bytes.SIZEOF_INT +
+      40 * ClassSize.REFERENCE + 2 * Bytes.SIZEOF_INT +
       (12 * Bytes.SIZEOF_LONG) +
       4 * Bytes.SIZEOF_BOOLEAN);
 
@@ -6491,33 +6485,4 @@ public class HRegion implements HeapSize, PropagatingConfigurationObserver { //
       this.log.sync();
     }
   }
-
-  /**
-   * {@inheritDoc}
-   */
-  @Override
-  public void onConfigurationChange(Configuration conf) {
-    // Do nothing for now.
-  }
-
-  /**
-   * {@inheritDoc}
-   */
-  @Override
-  public void registerChildren(ConfigurationManager manager) {
-    configurationManager = Optional.of(manager);
-    for (Store s : this.stores.values()) {
-      configurationManager.get().registerObserver(s);
-    }
-  }
-
-  /**
-   * {@inheritDoc}
-   */
-  @Override
-  public void deregisterChildren(ConfigurationManager manager) {
-    for (Store s : this.stores.values()) {
-      configurationManager.get().deregisterObserver(s);
-    }
-  }
 }

http://git-wip-us.apache.org/repos/asf/hbase/blob/2822a289/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/HRegionServer.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/HRegionServer.java b/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/HRegionServer.java
index 1391faa..6e08b6f 100644
--- a/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/HRegionServer.java
+++ b/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/HRegionServer.java
@@ -77,8 +77,6 @@ import org.apache.hadoop.hbase.classification.InterfaceAudience;
 import org.apache.hadoop.hbase.client.ConnectionUtils;
 import org.apache.hadoop.hbase.client.HConnection;
 import org.apache.hadoop.hbase.client.HConnectionManager;
-import org.apache.hadoop.hbase.conf.ConfigurationManager;
-import org.apache.hadoop.hbase.conf.ConfigurationObserver;
 import org.apache.hadoop.hbase.coordination.BaseCoordinatedStateManager;
 import org.apache.hadoop.hbase.coordination.CloseRegionCoordination;
 import org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination;
@@ -433,12 +431,6 @@ public class HRegionServer extends HasThread implements
   private final boolean useZKForAssignment;
 
   /**
-   * Configuration manager is used to register/deregister and notify the configuration observers
-   * when the regionserver is notified that there was a change in the on disk configs.
-   */
-  private final ConfigurationManager configurationManager;
-
-  /**
    * Starts a HRegionServer at the default location.
    * @param conf
    * @throws IOException
@@ -539,7 +531,6 @@ public class HRegionServer extends HasThread implements
       clusterStatusTracker = new ClusterStatusTracker(zooKeeper, this);
       clusterStatusTracker.start();
     }
-    this.configurationManager = new ConfigurationManager();
 
     rpcServices.start();
     putUpWebUI();
@@ -772,12 +763,6 @@ public class HRegionServer extends HasThread implements
     if (storefileRefreshPeriod > 0) {
       this.storefileRefresher = new StorefileRefresherChore(storefileRefreshPeriod, this, this);
     }
-    registerConfigurationObservers();
-  }
-
-  private void registerConfigurationObservers() {
-    // Registering the compactSplitThread object with the ConfigurationManager.
-    configurationManager.registerObserver(this.compactSplitThread);
   }
 
   /**
@@ -2264,7 +2249,6 @@ public class HRegionServer extends HasThread implements
   @Override
   public void addToOnlineRegions(HRegion region) {
     this.onlineRegions.put(region.getRegionInfo().getEncodedName(), region);
-    configurationManager.registerObserver(region);
   }
 
   /**
@@ -3063,12 +3047,4 @@ public class HRegionServer extends HasThread implements
   public CacheConfig getCacheConfig() {
     return this.cacheConfig;
   }
-
-  /**
-   * @return : Returns the ConfigurationManager object for testing purposes.
-   */
-  protected ConfigurationManager getConfigurationManager() {
-    return configurationManager;
-    
-  }
 }

http://git-wip-us.apache.org/repos/asf/hbase/blob/2822a289/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/HStore.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/HStore.java b/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/HStore.java
index 097af91..d732439 100644
--- a/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/HStore.java
+++ b/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/HStore.java
@@ -59,7 +59,6 @@ import org.apache.hadoop.hbase.KeyValue;
 import org.apache.hadoop.hbase.RemoteExceptionHandler;
 import org.apache.hadoop.hbase.TableName;
 import org.apache.hadoop.hbase.client.Scan;
-import org.apache.hadoop.hbase.conf.ConfigurationManager;
 import org.apache.hadoop.hbase.io.compress.Compression;
 import org.apache.hadoop.hbase.io.crypto.Cipher;
 import org.apache.hadoop.hbase.io.crypto.Encryption;
@@ -91,7 +90,6 @@ import org.apache.hadoop.hbase.util.ReflectionUtils;
 import org.apache.hadoop.util.StringUtils;
 
 import com.google.common.annotations.VisibleForTesting;
-import com.google.common.base.Optional;
 import com.google.common.base.Preconditions;
 import com.google.common.collect.ImmutableCollection;
 import com.google.common.collect.ImmutableList;
@@ -137,7 +135,7 @@ public class HStore implements Store {
   private final HRegion region;
   private final HColumnDescriptor family;
   private final HRegionFileSystem fs;
-  private Configuration conf;
+  private final Configuration conf;
   private final CacheConfig cacheConf;
   private long lastCompactSize = 0;
   volatile boolean forceMajor = false;
@@ -180,7 +178,7 @@ public class HStore implements Store {
   final StoreEngine<?, ?, ?, ?> storeEngine;
 
   private static final AtomicBoolean offPeakCompactionTracker = new AtomicBoolean();
-  private volatile OffPeakHours offPeakHours;
+  private final OffPeakHours offPeakHours;
 
   private static final int DEFAULT_FLUSH_RETRIES_NUMBER = 10;
   private int flushRetriesNumber;
@@ -2203,44 +2201,4 @@ public class HStore implements Store {
   public long getMajorCompactedCellsSize() {
     return majorCompactedCellsSize;
   }
-
-  /**
-   * Returns the StoreEngine that is backing this concrete implementation of Store.
-   * @return Returns the {@link StoreEngine} object used internally inside this HStore object.
-   */
-  protected StoreEngine<?, ?, ?, ?> getStoreEngine() {
-    return this.storeEngine;
-  }
-
-  protected OffPeakHours getOffPeakHours() {
-    return this.offPeakHours;
-  }
-
-  /**
-   * {@inheritDoc}
-   */
-  @Override
-  public void onConfigurationChange(Configuration conf) {
-    this.conf = new CompoundConfiguration()
-            .add(conf)
-            .addBytesMap(family.getValues());
-    this.storeEngine.compactionPolicy.setConf(conf);
-    this.offPeakHours = OffPeakHours.getInstance(conf);
-  }
-
-  /**
-   * {@inheritDoc}
-   */
-  @Override
-  public void registerChildren(ConfigurationManager manager) {
-    // No children to register
-  }
-
-  /**
-   * {@inheritDoc}
-   */
-  @Override
-  public void deregisterChildren(ConfigurationManager manager) {
-    // No children to deregister
-  }
 }

http://git-wip-us.apache.org/repos/asf/hbase/blob/2822a289/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/Store.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/Store.java b/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/Store.java
index 70faff1..9078c44 100644
--- a/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/Store.java
+++ b/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/Store.java
@@ -32,8 +32,6 @@ import org.apache.hadoop.hbase.HRegionInfo;
 import org.apache.hadoop.hbase.KeyValue;
 import org.apache.hadoop.hbase.TableName;
 import org.apache.hadoop.hbase.client.Scan;
-import org.apache.hadoop.hbase.conf.ConfigurationObserver;
-import org.apache.hadoop.hbase.conf.PropagatingConfigurationObserver;
 import org.apache.hadoop.hbase.io.HeapSize;
 import org.apache.hadoop.hbase.io.compress.Compression;
 import org.apache.hadoop.hbase.io.hfile.CacheConfig;
@@ -50,7 +48,7 @@ import org.apache.hadoop.hbase.util.Pair;
  */
 @InterfaceAudience.Private
 @InterfaceStability.Evolving
-public interface Store extends HeapSize, StoreConfigInformation, PropagatingConfigurationObserver {
+public interface Store extends HeapSize, StoreConfigInformation {
 
   /* The default priority for user-specified compaction requests.
    * The user gets top priority unless we have blocking compactions. (Pri <= 0)

http://git-wip-us.apache.org/repos/asf/hbase/blob/2822a289/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/compactions/CompactionConfiguration.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/compactions/CompactionConfiguration.java b/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/compactions/CompactionConfiguration.java
index 8d8fcd0..47576c6 100644
--- a/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/compactions/CompactionConfiguration.java
+++ b/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/compactions/CompactionConfiguration.java
@@ -40,6 +40,7 @@ import org.apache.hadoop.hbase.regionserver.StoreConfigInformation;
  * Set parameter as "hbase.hstore.compaction.<attribute>"
  */
 
+//TODO: revisit this class for online parameter updating (both in xml and on the CF)
 @InterfaceAudience.Private
 public class CompactionConfiguration {
 
@@ -54,22 +55,19 @@ public class CompactionConfiguration {
   public static final String HBASE_HSTORE_COMPACTION_MAX_KEY = "hbase.hstore.compaction.max";
   public static final String HBASE_HSTORE_COMPACTION_MAX_SIZE_KEY =
     "hbase.hstore.compaction.max.size";
-  public static final String HBASE_HSTORE_OFFPEAK_END_HOUR = "hbase.offpeak.end.hour";
-  public static final String HBASE_HSTORE_OFFPEAK_START_HOUR = "hbase.offpeak.start.hour";
 
   Configuration conf;
   StoreConfigInformation storeConfigInfo;
 
-  private final double offPeakCompactionRatio;
-  /** Since all these properties can change online, they are volatile **/
-  private final long maxCompactSize;
-  private final long minCompactSize;
-  private final int minFilesToCompact;
-  private final int maxFilesToCompact;
-  private final double compactionRatio;
-  private final long throttlePoint;
-  private final long majorCompactionPeriod;
-  private final float majorCompactionJitter;
+  long maxCompactSize;
+  long minCompactSize;
+  int minFilesToCompact;
+  int maxFilesToCompact;
+  double compactionRatio;
+  double offPeekCompactionRatio;
+  long throttlePoint;
+  long majorCompactionPeriod;
+  float majorCompactionJitter;
 
   CompactionConfiguration(Configuration conf, StoreConfigInformation storeConfigInfo) {
     this.conf = conf;
@@ -82,9 +80,9 @@ public class CompactionConfiguration {
           /*old name*/ conf.getInt("hbase.hstore.compactionThreshold", 3)));
     maxFilesToCompact = conf.getInt(HBASE_HSTORE_COMPACTION_MAX_KEY, 10);
     compactionRatio = conf.getFloat(HBASE_HSTORE_COMPACTION_RATIO_KEY, 1.2F);
-    offPeakCompactionRatio = conf.getFloat(HBASE_HSTORE_COMPACTION_RATIO_OFFPEAK_KEY, 5.0F);
+    offPeekCompactionRatio = conf.getFloat(HBASE_HSTORE_COMPACTION_RATIO_OFFPEAK_KEY, 5.0F);
 
-    throttlePoint = conf.getLong("hbase.regionserver.thread.compaction.throttle",
+    throttlePoint =  conf.getLong("hbase.regionserver.thread.compaction.throttle",
           2 * maxFilesToCompact * storeConfigInfo.getMemstoreFlushSize());
     majorCompactionPeriod = conf.getLong(HConstants.MAJOR_COMPACTION_PERIOD, 1000*60*60*24*7);
     // Make it 0.5 so jitter has us fall evenly either side of when the compaction should run
@@ -103,7 +101,7 @@ public class CompactionConfiguration {
       minFilesToCompact,
       maxFilesToCompact,
       compactionRatio,
-      offPeakCompactionRatio,
+      offPeekCompactionRatio,
       throttlePoint,
       majorCompactionPeriod,
       majorCompactionJitter);
@@ -112,49 +110,49 @@ public class CompactionConfiguration {
   /**
    * @return lower bound below which compaction is selected without ratio test
    */
-  public long getMinCompactSize() {
+  long getMinCompactSize() {
     return minCompactSize;
   }
 
   /**
    * @return upper bound on file size to be included in minor compactions
    */
-  public long getMaxCompactSize() {
+  long getMaxCompactSize() {
     return maxCompactSize;
   }
 
   /**
    * @return upper bound on number of files to be included in minor compactions
    */
-  public int getMinFilesToCompact() {
+  int getMinFilesToCompact() {
     return minFilesToCompact;
   }
 
   /**
    * @return upper bound on number of files to be included in minor compactions
    */
-  public int getMaxFilesToCompact() {
+  int getMaxFilesToCompact() {
     return maxFilesToCompact;
   }
 
   /**
    * @return Ratio used for compaction
    */
-  public double getCompactionRatio() {
+  double getCompactionRatio() {
     return compactionRatio;
   }
 
   /**
    * @return Off peak Ratio used for compaction
    */
-  public double getCompactionRatioOffPeak() {
-    return offPeakCompactionRatio;
+  double getCompactionRatioOffPeak() {
+    return offPeekCompactionRatio;
   }
 
   /**
    * @return ThrottlePoint used for classifying small and large compactions
    */
-  public long getThrottlePoint() {
+  long getThrottlePoint() {
     return throttlePoint;
   }
 
@@ -162,7 +160,7 @@ public class CompactionConfiguration {
    * @return Major compaction period from compaction.
    * Major compactions are selected periodically according to this parameter plus jitter
    */
-  public long getMajorCompactionPeriod() {
+  long getMajorCompactionPeriod() {
     return majorCompactionPeriod;
   }
 
@@ -170,7 +168,7 @@ public class CompactionConfiguration {
    * @return Major the jitter fraction, the fraction within which the major compaction
    *  period is randomly chosen from the majorCompactionPeriod in each store.
    */
-  public float getMajorCompactionJitter() {
+  float getMajorCompactionJitter() {
     return majorCompactionJitter;
   }
 }

http://git-wip-us.apache.org/repos/asf/hbase/blob/2822a289/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/compactions/CompactionPolicy.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/compactions/CompactionPolicy.java b/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/compactions/CompactionPolicy.java
index d31c9b8..efe3066 100644
--- a/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/compactions/CompactionPolicy.java
+++ b/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/compactions/CompactionPolicy.java
@@ -21,6 +21,7 @@ package org.apache.hadoop.hbase.regionserver.compactions;
 
 import java.io.IOException;
 import java.util.Collection;
+import java.util.List;
 
 import org.apache.hadoop.hbase.classification.InterfaceAudience;
 import org.apache.hadoop.conf.Configuration;
@@ -61,11 +62,4 @@ public abstract class CompactionPolicy {
   public void setConf(Configuration conf) {
     this.comConf = new CompactionConfiguration(conf, this.storeConfigInfo);
   }
-
-  /**
-   * @return The current compaction configuration settings.
-   */
-  public CompactionConfiguration getConf() {
-    return this.comConf;
-  }
 }

http://git-wip-us.apache.org/repos/asf/hbase/blob/2822a289/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/compactions/OffPeakHours.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/compactions/OffPeakHours.java b/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/compactions/OffPeakHours.java
index 37b997b..d51c2fa 100644
--- a/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/compactions/OffPeakHours.java
+++ b/hbase-server/src/main/java/org/apache/hadoop/hbase/regionserver/compactions/OffPeakHours.java
@@ -32,8 +32,8 @@ public abstract class OffPeakHours {
   };
 
   public static OffPeakHours getInstance(Configuration conf) {
-    int startHour = conf.getInt(CompactionConfiguration.HBASE_HSTORE_OFFPEAK_START_HOUR, -1);
-    int endHour = conf.getInt(CompactionConfiguration.HBASE_HSTORE_OFFPEAK_END_HOUR, -1);
+    int startHour = conf.getInt("hbase.offpeak.start.hour", -1);
+    int endHour = conf.getInt("hbase.offpeak.end.hour", -1);
     return getInstance(startHour, endHour);
   }
 

http://git-wip-us.apache.org/repos/asf/hbase/blob/2822a289/hbase-server/src/test/java/org/apache/hadoop/hbase/conf/TestConfigurationManager.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/conf/TestConfigurationManager.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/conf/TestConfigurationManager.java
deleted file mode 100644
index 51552a5..0000000
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/conf/TestConfigurationManager.java
+++ /dev/null
@@ -1,133 +0,0 @@
-/**
- * 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.hadoop.hbase.conf;
-
-import junit.framework.TestCase;
-
-import org.apache.commons.logging.Log;
-import org.apache.commons.logging.LogFactory;
-import org.apache.hadoop.conf.Configuration;
-import org.apache.hadoop.hbase.testclassification.ClientTests;
-import org.apache.hadoop.hbase.testclassification.SmallTests;
-import org.junit.experimental.categories.Category;
-
-@Category({SmallTests.class, ClientTests.class})
-public class TestConfigurationManager extends TestCase {
-  public static final Log LOG = LogFactory.getLog(TestConfigurationManager.class);
-
-  class DummyConfigurationObserver implements ConfigurationObserver {
-    private boolean notifiedOnChange = false;
-    private ConfigurationManager cm;
-
-    public DummyConfigurationObserver(ConfigurationManager cm) {
-      this.cm = cm;
-      register();
-    }
-
-    public void onConfigurationChange(Configuration conf) {
-      notifiedOnChange = true;
-    }
-
-    // Was the observer notified on Configuration change?
-    public boolean wasNotifiedOnChange() {
-      return notifiedOnChange;
-    }
-
-    public void resetNotifiedOnChange() {
-      notifiedOnChange = false;
-    }
-
-    public void register() {
-      this.cm.registerObserver(this);
-    }
-
-    public void deregister() {
-      this.cm.deregisterObserver(this);
-    }
-  }
-
-  /**
-   * Test if observers get notified by the <code>ConfigurationManager</code>
-   * when the Configuration is reloaded.
-   */
-  public void testCheckIfObserversNotified() {
-    Configuration conf = new Configuration();
-    ConfigurationManager cm = new ConfigurationManager();
-    DummyConfigurationObserver d1 = new DummyConfigurationObserver(cm);
-
-    // Check if we get notified.
-    cm.notifyAllObservers(conf);
-    assertTrue(d1.wasNotifiedOnChange());
-    d1.resetNotifiedOnChange();
-
-    // Now check if we get notified on change with more than one observers.
-    DummyConfigurationObserver d2 = new DummyConfigurationObserver(cm);
-    cm.notifyAllObservers(conf);
-    assertTrue(d1.wasNotifiedOnChange());
-    d1.resetNotifiedOnChange();
-    assertTrue(d2.wasNotifiedOnChange());
-    d2.resetNotifiedOnChange();
-
-    // Now try deregistering an observer and verify that it was not notified
-    d2.deregister();
-    cm.notifyAllObservers(conf);
-    assertTrue(d1.wasNotifiedOnChange());
-    d1.resetNotifiedOnChange();
-    assertFalse(d2.wasNotifiedOnChange());
-  }
-
-  // Register an observer that will go out of scope immediately, allowing
-  // us to test that out of scope observers are deregistered.
-  private void registerLocalObserver(ConfigurationManager cm) {
-    new DummyConfigurationObserver(cm);
-  }
-
-  /**
-   * Test if out-of-scope observers are deregistered on GC.
-   */
-  public void testDeregisterOnOutOfScope() {
-    Configuration conf = new Configuration();
-    ConfigurationManager cm = new ConfigurationManager();
-
-    boolean outOfScopeObserversDeregistered = false;
-
-    // On my machine, I was able to cause a GC after around 5 iterations.
-    // If we do not cause a GC in 100k iterations, which is very unlikely,
-    // there might be something wrong with the GC.
-    for (int i = 0; i < 100000; i++) {
-      registerLocalObserver(cm);
-      cm.notifyAllObservers(conf);
-
-      // 'Suggest' the system to do a GC. We should be able to cause GC
-      // atleast once in the 2000 iterations.
-      System.gc();
-
-      // If GC indeed happened, all the observers (which are all out of scope),
-      // should have been deregistered.
-      if (cm.getNumObservers() <= i) {
-        outOfScopeObserversDeregistered = true;
-        break;
-      }
-    }
-    if (!outOfScopeObserversDeregistered) {
-      LOG.warn("Observers were not GC-ed! Something seems to be wrong.");
-    }
-    assertTrue(outOfScopeObserversDeregistered);
-  }
-}

http://git-wip-us.apache.org/repos/asf/hbase/blob/2822a289/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionServerOnlineConfigChange.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionServerOnlineConfigChange.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionServerOnlineConfigChange.java
deleted file mode 100644
index 5c92c8f..0000000
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/TestRegionServerOnlineConfigChange.java
+++ /dev/null
@@ -1,206 +0,0 @@
-/**
- * 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.hadoop.hbase.regionserver;
-
-import junit.framework.TestCase;
-
-import org.apache.commons.logging.Log;
-import org.apache.commons.logging.LogFactory;
-import org.apache.hadoop.conf.Configuration;
-import org.apache.hadoop.hbase.HBaseTestingUtility;
-import org.apache.hadoop.hbase.HConstants;
-import org.apache.hadoop.hbase.HRegionInfo;
-import org.apache.hadoop.hbase.client.HTable;
-import org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration;
-import org.apache.hadoop.hbase.testclassification.ClientTests;
-import org.apache.hadoop.hbase.testclassification.MediumTests;
-import org.apache.hadoop.hbase.util.Bytes;
-import org.junit.experimental.categories.Category;
-
-import java.io.IOException;
-
-/**
- * Verify that the Online config Changes on the HRegionServer side are actually
- * happening. We should add tests for important configurations which will be
- * changed online.
- */
-
-@Category({MediumTests.class})
-public class TestRegionServerOnlineConfigChange extends TestCase {
-  static final Log LOG =
-          LogFactory.getLog(TestRegionServerOnlineConfigChange.class.getName());
-  HBaseTestingUtility hbaseTestingUtility = new HBaseTestingUtility();
-  Configuration conf = null;
-
-  HTable t1 = null;
-  HRegionServer rs1 = null;
-  byte[] r1name = null;
-  HRegion r1 = null;
-
-  final String table1Str = "table1";
-  final String columnFamily1Str = "columnFamily1";
-  final byte[] TABLE1 = Bytes.toBytes(table1Str);
-  final byte[] COLUMN_FAMILY1 = Bytes.toBytes(columnFamily1Str);
-
-
-  @Override
-  public void setUp() throws Exception {
-    conf = hbaseTestingUtility.getConfiguration();
-    hbaseTestingUtility.startMiniCluster(1,1);
-    t1 = hbaseTestingUtility.createTable(TABLE1, COLUMN_FAMILY1);
-    @SuppressWarnings("deprecation")
-    HRegionInfo firstHRI = t1.getRegionLocations().keySet().iterator().next();
-    r1name = firstHRI.getRegionName();
-    rs1 = hbaseTestingUtility.getHBaseCluster().getRegionServer(
-        hbaseTestingUtility.getHBaseCluster().getServerWith(r1name));
-    r1 = rs1.getRegion(r1name);
-  }
-
-  @Override
-  public void tearDown() throws Exception {
-    hbaseTestingUtility.shutdownMiniCluster();
-  }
-
-  /**
-   * Check if the number of compaction threads changes online
-   * @throws IOException
-   */
-  public void testNumCompactionThreadsOnlineChange() throws IOException {
-    assertTrue(rs1.compactSplitThread != null);
-    int newNumSmallThreads =
-            rs1.compactSplitThread.getSmallCompactionThreadNum() + 1;
-    int newNumLargeThreads =
-            rs1.compactSplitThread.getLargeCompactionThreadNum() + 1;
-
-    conf.setInt("hbase.regionserver.thread.compaction.small",
-            newNumSmallThreads);
-    conf.setInt("hbase.regionserver.thread.compaction.large",
-            newNumLargeThreads);
-    rs1.getConfigurationManager().notifyAllObservers(conf);
-
-    assertEquals(newNumSmallThreads,
-                  rs1.compactSplitThread.getSmallCompactionThreadNum());
-    assertEquals(newNumLargeThreads,
-                  rs1.compactSplitThread.getLargeCompactionThreadNum());
-  }
-
-  /**
-   * Test that the configurations in the CompactionConfiguration class change
-   * properly.
-   *
-   * @throws IOException
-   */
-  public void testCompactionConfigurationOnlineChange() throws IOException {
-    String strPrefix = "hbase.hstore.compaction.";
-    Store s = r1.getStore(COLUMN_FAMILY1);
-    if (!(s instanceof HStore)) {
-      LOG.error("Can't test the compaction configuration of HStore class. "
-          + "Got a different implementation other than HStore");
-      return;
-    }
-    HStore hstore = (HStore)s;
-
-    // Set the new compaction ratio to a different value.
-    double newCompactionRatio = 
-            hstore.getStoreEngine().getCompactionPolicy().getConf().getCompactionRatio() + 0.1;
-    conf.setFloat(strPrefix + "ratio", (float)newCompactionRatio);
-
-    // Notify all the observers, which includes the Store object.
-    rs1.getConfigurationManager().notifyAllObservers(conf);
-
-    // Check if the compaction ratio got updated in the Compaction Configuration
-    assertEquals(newCompactionRatio,
-                 hstore.getStoreEngine().getCompactionPolicy().getConf().getCompactionRatio(),
-                 0.00001);
-
-    // Check if the off peak compaction ratio gets updated.
-    double newOffPeakCompactionRatio =
-        hstore.getStoreEngine().getCompactionPolicy().getConf().getCompactionRatioOffPeak() + 0.1;
-    conf.setFloat(strPrefix + "ratio.offpeak",
-            (float)newOffPeakCompactionRatio);
-    rs1.getConfigurationManager().notifyAllObservers(conf);
-    assertEquals(newOffPeakCompactionRatio,
-        hstore.getStoreEngine().getCompactionPolicy().getConf().getCompactionRatioOffPeak(),
-                 0.00001);
-
-    // Check if the throttle point gets updated.
-    long newThrottlePoint =
-        hstore.getStoreEngine().getCompactionPolicy().getConf().getThrottlePoint() + 10;
-    conf.setLong("hbase.regionserver.thread.compaction.throttle",
-                  newThrottlePoint);
-    rs1.getConfigurationManager().notifyAllObservers(conf);
-    assertEquals(newThrottlePoint,
-        hstore.getStoreEngine().getCompactionPolicy().getConf().getThrottlePoint());
-
-    // Check if the minFilesToCompact gets updated.
-    int newMinFilesToCompact =
-            hstore.getStoreEngine().getCompactionPolicy().getConf().getMinFilesToCompact() + 1;
-    conf.setLong(strPrefix + "min", newMinFilesToCompact);
-    rs1.getConfigurationManager().notifyAllObservers(conf);
-    assertEquals(newMinFilesToCompact,
-        hstore.getStoreEngine().getCompactionPolicy().getConf().getMinFilesToCompact());
-
-    // Check if the maxFilesToCompact gets updated.
-    int newMaxFilesToCompact =
-            hstore.getStoreEngine().getCompactionPolicy().getConf().getMaxFilesToCompact() + 1;
-    conf.setLong(strPrefix + "max", newMaxFilesToCompact);
-    rs1.getConfigurationManager().notifyAllObservers(conf);
-    assertEquals(newMaxFilesToCompact,
-        hstore.getStoreEngine().getCompactionPolicy().getConf().getMaxFilesToCompact());
-
-    // Check OffPeak hours is updated in an online fashion.
-    conf.setLong(CompactionConfiguration.HBASE_HSTORE_OFFPEAK_START_HOUR, 6);
-    conf.setLong(CompactionConfiguration.HBASE_HSTORE_OFFPEAK_END_HOUR, 7);
-    rs1.getConfigurationManager().notifyAllObservers(conf);
-    assertFalse(hstore.getOffPeakHours().isOffPeakHour(4));
-
-    // Check if the minCompactSize gets updated.
-    long newMinCompactSize =
-            hstore.getStoreEngine().getCompactionPolicy().getConf().getMinCompactSize() + 1;
-    conf.setLong(strPrefix + "min.size", newMinCompactSize);
-    rs1.getConfigurationManager().notifyAllObservers(conf);
-    assertEquals(newMinCompactSize,
-                 hstore.getStoreEngine().getCompactionPolicy().getConf().getMinCompactSize());
-
-    // Check if the maxCompactSize gets updated.
-    long newMaxCompactSize =
-            hstore.getStoreEngine().getCompactionPolicy().getConf().getMaxCompactSize() - 1;
-    conf.setLong(strPrefix + "max.size", newMaxCompactSize);
-    rs1.getConfigurationManager().notifyAllObservers(conf);
-    assertEquals(newMaxCompactSize,
-                 hstore.getStoreEngine().getCompactionPolicy().getConf().getMaxCompactSize());
-
-    // Check if majorCompactionPeriod gets updated.
-    long newMajorCompactionPeriod =
-            hstore.getStoreEngine().getCompactionPolicy().getConf().getMajorCompactionPeriod() + 10;
-    conf.setLong(HConstants.MAJOR_COMPACTION_PERIOD, newMajorCompactionPeriod);
-    rs1.getConfigurationManager().notifyAllObservers(conf);
-    assertEquals(newMajorCompactionPeriod,
-            hstore.getStoreEngine().getCompactionPolicy().getConf().getMajorCompactionPeriod());
-
-    // Check if majorCompactionJitter gets updated.
-    float newMajorCompactionJitter =
-        hstore.getStoreEngine().getCompactionPolicy().getConf().getMajorCompactionJitter() + 0.02F;
-    conf.setFloat("hbase.hregion.majorcompaction.jitter",
-                  newMajorCompactionJitter);
-    rs1.getConfigurationManager().notifyAllObservers(conf);
-    assertEquals(newMajorCompactionJitter,
-      hstore.getStoreEngine().getCompactionPolicy().getConf().getMajorCompactionJitter(), 0.00001);
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/hbase/blob/2822a289/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/compactions/TestOffPeakHours.java
----------------------------------------------------------------------
diff --git a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/compactions/TestOffPeakHours.java b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/compactions/TestOffPeakHours.java
index 93a10f1..d2f955c 100644
--- a/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/compactions/TestOffPeakHours.java
+++ b/hbase-server/src/test/java/org/apache/hadoop/hbase/regionserver/compactions/TestOffPeakHours.java
@@ -61,16 +61,16 @@ public class TestOffPeakHours {
 
   @Test
   public void testSetPeakHourToTargetTime() {
-    conf.setLong(CompactionConfiguration.HBASE_HSTORE_OFFPEAK_START_HOUR, hourMinusOne);
-    conf.setLong(CompactionConfiguration.HBASE_HSTORE_OFFPEAK_END_HOUR, hourPlusOne);
+    conf.setLong("hbase.offpeak.start.hour", hourMinusOne);
+    conf.setLong("hbase.offpeak.end.hour", hourPlusOne);
     OffPeakHours target = OffPeakHours.getInstance(conf);
     assertTrue(target.isOffPeakHour(hourOfDay));
   }
 
   @Test
   public void testSetPeakHourOutsideCurrentSelection() {
-    conf.setLong(CompactionConfiguration.HBASE_HSTORE_OFFPEAK_START_HOUR, hourMinusTwo);
-    conf.setLong(CompactionConfiguration.HBASE_HSTORE_OFFPEAK_END_HOUR, hourMinusOne);
+    conf.setLong("hbase.offpeak.start.hour", hourMinusTwo);
+    conf.setLong("hbase.offpeak.end.hour", hourMinusOne);
     OffPeakHours target = OffPeakHours.getInstance(conf);
     assertFalse(target.isOffPeakHour(hourOfDay));
   }