You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hbase.apache.org by ec...@apache.org on 2014/12/26 20:12:29 UTC

[4/5] hbase git commit: Adding license headers to the hbase-consensus module

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/metrics/PeerMetrics.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/metrics/PeerMetrics.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/metrics/PeerMetrics.java
index efa9df6..8119cb9 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/metrics/PeerMetrics.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/metrics/PeerMetrics.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.metrics;
 
+/*
+ * 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.
+ */
+
+
 import io.airlift.stats.CounterStat;
 import io.airlift.stats.Distribution;
 import org.apache.hadoop.hbase.metrics.MetricsBase;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/protocol/ConsensusHost.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/protocol/ConsensusHost.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/protocol/ConsensusHost.java
index ffa6f12..878f153 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/protocol/ConsensusHost.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/protocol/ConsensusHost.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.protocol;
 
+/*
+ * 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.
+ */
+
+
 import com.facebook.swift.codec.ThriftConstructor;
 import com.facebook.swift.codec.ThriftField;
 import com.facebook.swift.codec.ThriftStruct;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/protocol/DataStoreCommitEvent.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/protocol/DataStoreCommitEvent.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/protocol/DataStoreCommitEvent.java
index fcfd1bb..0fe3f14 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/protocol/DataStoreCommitEvent.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/protocol/DataStoreCommitEvent.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.protocol;
 
+/*
+ * 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.
+ */
+
+
 import com.lmax.disruptor.EventFactory;
 
 /**

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/protocol/EditId.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/protocol/EditId.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/protocol/EditId.java
index 3bb860b..262b301 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/protocol/EditId.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/protocol/EditId.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.protocol;
 
+/*
+ * 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.
+ */
+
+
 import com.facebook.swift.codec.ThriftConstructor;
 import com.facebook.swift.codec.ThriftField;
 import com.facebook.swift.codec.ThriftStruct;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/protocol/Payload.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/protocol/Payload.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/protocol/Payload.java
index 5c6a4a3..cddcbaf 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/protocol/Payload.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/protocol/Payload.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.protocol;
 
+/*
+ * 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.
+ */
+
+
 import com.google.common.util.concurrent.SettableFuture;
 import java.nio.ByteBuffer;
 

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/AbstractPeerManager.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/AbstractPeerManager.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/AbstractPeerManager.java
index e81578d..766dc2a 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/AbstractPeerManager.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/AbstractPeerManager.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.quorum;
 
+/*
+ * 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.
+ */
+
+
 import org.apache.hadoop.hbase.HConstants;
 import org.apache.hadoop.hbase.HServerAddress;
 import org.apache.hadoop.hbase.consensus.protocol.EditId;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/AggregateTimer.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/AggregateTimer.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/AggregateTimer.java
index d10ef7a..e032971 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/AggregateTimer.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/AggregateTimer.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.quorum;
 
+/*
+ * 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.
+ */
+
+
 import java.util.Set;
 import java.util.concurrent.ConcurrentSkipListSet;
 import java.util.concurrent.Executors;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/AppendConsensusSession.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/AppendConsensusSession.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/AppendConsensusSession.java
index ec46247..d217357 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/AppendConsensusSession.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/AppendConsensusSession.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.quorum;
 
+/*
+ * 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.
+ */
+
+
 import org.apache.hadoop.hbase.consensus.metrics.ConsensusMetrics;
 import org.apache.hadoop.hbase.consensus.protocol.EditId;
 import org.apache.hadoop.hbase.consensus.raft.events.ReplicateEntriesEvent;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/AppendConsensusSessionInterface.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/AppendConsensusSessionInterface.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/AppendConsensusSessionInterface.java
index 44c483b..54af301 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/AppendConsensusSessionInterface.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/AppendConsensusSessionInterface.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.quorum;
 
+/*
+ * 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.
+ */
+
+
 import org.apache.hadoop.hbase.consensus.protocol.EditId;
 import org.apache.hadoop.hbase.consensus.raft.events.ReplicateEntriesEvent;
 import org.apache.hadoop.hbase.consensus.rpc.AppendRequest;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/AppendResponseCallBack.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/AppendResponseCallBack.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/AppendResponseCallBack.java
index 12b9e79..8553ddf 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/AppendResponseCallBack.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/AppendResponseCallBack.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.quorum;
 
+/*
+ * 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.
+ */
+
+
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/ConsensusSession.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/ConsensusSession.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/ConsensusSession.java
index 448dcf8..7e2b3a2 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/ConsensusSession.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/ConsensusSession.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.quorum;
 
+/*
+ * 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.
+ */
+
+
 import org.apache.hadoop.hbase.consensus.protocol.EditId;
 
 public interface ConsensusSession {

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/ConstituentTimer.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/ConstituentTimer.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/ConstituentTimer.java
index 8b11a32..049bb5f 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/ConstituentTimer.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/ConstituentTimer.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.quorum;
 
+/*
+ * 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.
+ */
+
+
 import org.apache.commons.logging.Log;
 import org.apache.commons.logging.LogFactory;
 

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/HeartbeatTimeoutCallback.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/HeartbeatTimeoutCallback.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/HeartbeatTimeoutCallback.java
index 77f8718..8601376 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/HeartbeatTimeoutCallback.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/HeartbeatTimeoutCallback.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.quorum;
 
+/*
+ * 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.
+ */
+
+
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 import org.apache.hadoop.hbase.consensus.raft.events.ReplicateEntriesEvent;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/ImmutableRaftContext.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/ImmutableRaftContext.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/ImmutableRaftContext.java
index fdfa4bd..1eb2083 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/ImmutableRaftContext.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/ImmutableRaftContext.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.quorum;
 
+/*
+ * 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.
+ */
+
+
 import org.apache.hadoop.conf.Configuration;
 import org.apache.hadoop.hbase.HServerAddress;
 import org.apache.hadoop.hbase.consensus.log.CommitLogManagerInterface;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/JointAppendConsensusSession.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/JointAppendConsensusSession.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/JointAppendConsensusSession.java
index 23c77e0..ff519cf 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/JointAppendConsensusSession.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/JointAppendConsensusSession.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.quorum;
 
+/*
+ * 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.
+ */
+
+
 import org.apache.hadoop.hbase.consensus.metrics.ConsensusMetrics;
 import org.apache.hadoop.hbase.consensus.protocol.EditId;
 import org.apache.hadoop.hbase.consensus.raft.events.ReplicateEntriesEvent;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/JointConsensusPeerManager.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/JointConsensusPeerManager.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/JointConsensusPeerManager.java
index a8830fa..8e06c3e 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/JointConsensusPeerManager.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/JointConsensusPeerManager.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.quorum;
 
+/*
+ * 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.
+ */
+
+
 import org.apache.hadoop.hbase.HServerAddress;
 import org.apache.hadoop.hbase.consensus.util.RaftUtil;
 import org.apache.hadoop.hbase.consensus.fsm.Event;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/JointVoteConsensusSession.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/JointVoteConsensusSession.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/JointVoteConsensusSession.java
index fb3abe3..eb81000 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/JointVoteConsensusSession.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/JointVoteConsensusSession.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.quorum;
 
+/*
+ * 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.
+ */
+
+
 import org.apache.hadoop.hbase.consensus.metrics.ConsensusMetrics;
 import org.apache.hadoop.hbase.consensus.protocol.EditId;
 import org.apache.hadoop.hbase.consensus.rpc.VoteRequest;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/MutableRaftContext.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/MutableRaftContext.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/MutableRaftContext.java
index 9802d21..815a040 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/MutableRaftContext.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/MutableRaftContext.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.quorum;
 
+/*
+ * 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.
+ */
+
+
 import java.io.IOException;
 import java.nio.ByteBuffer;
 import java.util.concurrent.ExecutorService;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/PeerManagerInterface.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/PeerManagerInterface.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/PeerManagerInterface.java
index 536a4ae..8a79dc9 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/PeerManagerInterface.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/PeerManagerInterface.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.quorum;
 
+/*
+ * 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.
+ */
+
+
 import org.apache.hadoop.hbase.consensus.metrics.ConsensusMetrics;
 import org.apache.hadoop.hbase.consensus.protocol.EditId;
 import org.apache.hadoop.hbase.consensus.raft.events.ReplicateEntriesEvent;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/ProgressTimeoutCallback.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/ProgressTimeoutCallback.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/ProgressTimeoutCallback.java
index 9cabd76..e526ddd 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/ProgressTimeoutCallback.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/ProgressTimeoutCallback.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.quorum;
 
+/*
+ * 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.
+ */
+
+
 import org.apache.hadoop.hbase.consensus.raft.events.ProgressTimeoutEvent;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/QuorumInfo.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/QuorumInfo.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/QuorumInfo.java
index 8755cbb..3c10bba 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/QuorumInfo.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/QuorumInfo.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.quorum;
 
+/*
+ * 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.
+ */
+
+
 import org.apache.hadoop.hbase.HConstants;
 import org.apache.hadoop.hbase.HServerAddress;
 import org.apache.hadoop.hbase.consensus.util.RaftUtil;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/QuorumMembershipChangeRequest.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/QuorumMembershipChangeRequest.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/QuorumMembershipChangeRequest.java
index 9d1d525..28c3376 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/QuorumMembershipChangeRequest.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/QuorumMembershipChangeRequest.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.quorum;
 
+/*
+ * 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.
+ */
+
+
 import com.google.common.util.concurrent.AbstractFuture;
 
 public class QuorumMembershipChangeRequest extends AbstractFuture<Boolean> {

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/RaftQuorumContext.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/RaftQuorumContext.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/RaftQuorumContext.java
index 5ad454a..2d736d7 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/RaftQuorumContext.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/RaftQuorumContext.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.quorum;
 
+/*
+ * 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.
+ */
+
+
 import com.google.common.util.concurrent.ListenableFuture;
 import org.apache.hadoop.conf.Configuration;
 import org.apache.hadoop.hbase.HConstants;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/RepeatingTimer.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/RepeatingTimer.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/RepeatingTimer.java
index b7bf1c5..986c739 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/RepeatingTimer.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/RepeatingTimer.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.quorum;
 
+/*
+ * 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.
+ */
+
+
 import java.util.concurrent.TimeUnit;
 import java.util.concurrent.Executors;
 import java.util.concurrent.ExecutorService;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/ReseedRequest.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/ReseedRequest.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/ReseedRequest.java
index 0175864..5c93cec 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/ReseedRequest.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/ReseedRequest.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.quorum;
 
+/*
+ * 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.
+ */
+
+
 import com.google.common.util.concurrent.SettableFuture;
 
 public class ReseedRequest {

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/SessionResult.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/SessionResult.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/SessionResult.java
index 144d9b2..ac381ac 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/SessionResult.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/SessionResult.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.quorum;
 
+/*
+ * 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.
+ */
+
+
 public enum SessionResult {
   MAJORITY_ACKED,
   STEP_DOWN,

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/SingleConsensusPeerManager.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/SingleConsensusPeerManager.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/SingleConsensusPeerManager.java
index 873676e..42eaf28 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/SingleConsensusPeerManager.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/SingleConsensusPeerManager.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.quorum;
 
+/*
+ * 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.
+ */
+
+
 import org.apache.hadoop.hbase.consensus.fsm.Event;
 import org.apache.hadoop.hbase.consensus.metrics.ConsensusMetrics;
 import org.apache.hadoop.hbase.consensus.raft.events.ReplicateEntriesEvent;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/TimeoutEventHandler.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/TimeoutEventHandler.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/TimeoutEventHandler.java
index 85c1607..a80c3c0 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/TimeoutEventHandler.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/TimeoutEventHandler.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.quorum;
 
+/*
+ * 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.
+ */
+
+
 public interface TimeoutEventHandler {
   void onTimeout();
 }

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/Timer.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/Timer.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/Timer.java
index 76c61fc..2cf1158 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/Timer.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/Timer.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.quorum;
 
+/*
+ * 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.
+ */
+
+
 import java.util.concurrent.TimeUnit;
 
 public interface Timer {

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/VoteConsensusSession.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/VoteConsensusSession.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/VoteConsensusSession.java
index 1a3fed1..ef85f67 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/VoteConsensusSession.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/VoteConsensusSession.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.quorum;
 
+/*
+ * 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.
+ */
+
+
 import org.apache.hadoop.hbase.consensus.metrics.ConsensusMetrics;
 import org.apache.hadoop.hbase.consensus.protocol.EditId;
 import org.apache.hadoop.hbase.consensus.rpc.VoteRequest;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/VoteConsensusSessionInterface.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/VoteConsensusSessionInterface.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/VoteConsensusSessionInterface.java
index 3215392..4f0d89f 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/VoteConsensusSessionInterface.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/quorum/VoteConsensusSessionInterface.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.quorum;
 
+/*
+ * 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.
+ */
+
+
 import org.apache.hadoop.hbase.consensus.protocol.EditId;
 import org.apache.hadoop.hbase.consensus.rpc.VoteRequest;
 

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/RaftStateMachine.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/RaftStateMachine.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/RaftStateMachine.java
index 3e30dcd..f5729c2 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/RaftStateMachine.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/RaftStateMachine.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft;
 
+/*
+ * 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.
+ */
+
+
 import org.apache.hadoop.hbase.consensus.fsm.*;
 import org.apache.hadoop.hbase.consensus.quorum.MutableRaftContext;
 import org.apache.hadoop.hbase.consensus.raft.events.*;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/AppendNotCompleted.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/AppendNotCompleted.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/AppendNotCompleted.java
index b76387c..c9edee3 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/AppendNotCompleted.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/AppendNotCompleted.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.events;
 
+/*
+ * 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.
+ */
+
+
 import org.apache.hadoop.hbase.consensus.quorum.AppendConsensusSessionInterface;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/AppendRequestEvent.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/AppendRequestEvent.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/AppendRequestEvent.java
index 2619f05..3e9a0a9 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/AppendRequestEvent.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/AppendRequestEvent.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.events;
 
+/*
+ * 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.
+ */
+
+
 import org.apache.hadoop.hbase.consensus.fsm.Event;
 import org.apache.hadoop.hbase.consensus.rpc.AppendRequest;
 import org.apache.hadoop.hbase.ipc.thrift.exceptions.ThriftHBaseException;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/AppendRequestTimeout.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/AppendRequestTimeout.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/AppendRequestTimeout.java
index ceda7e2..4a64982 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/AppendRequestTimeout.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/AppendRequestTimeout.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.events;
 
+/*
+ * 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.
+ */
+
+
 import org.apache.hadoop.hbase.consensus.fsm.Conditional;
 import org.apache.hadoop.hbase.consensus.fsm.Event;
 import org.apache.hadoop.hbase.consensus.quorum.AppendConsensusSessionInterface;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/AppendResponseEvent.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/AppendResponseEvent.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/AppendResponseEvent.java
index b6e8e9d..29eac7b 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/AppendResponseEvent.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/AppendResponseEvent.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.events;
 
+/*
+ * 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.
+ */
+
+
 import org.apache.hadoop.hbase.consensus.fsm.Event;
 import org.apache.hadoop.hbase.consensus.rpc.AppendResponse;
 

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/AppendRetry.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/AppendRetry.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/AppendRetry.java
index 59fd043..81435fc 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/AppendRetry.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/AppendRetry.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.events;
 
+/*
+ * 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.
+ */
+
+
 import org.apache.hadoop.hbase.consensus.fsm.Conditional;
 import org.apache.hadoop.hbase.consensus.fsm.Event;
 import org.apache.hadoop.hbase.consensus.quorum.AppendConsensusSession;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/AppendSucceeded.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/AppendSucceeded.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/AppendSucceeded.java
index c967cff..e44fe9b 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/AppendSucceeded.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/AppendSucceeded.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.events;
 
+/*
+ * 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.
+ */
+
+
 import org.apache.hadoop.hbase.consensus.fsm.Conditional;
 import org.apache.hadoop.hbase.consensus.fsm.Event;
 import org.apache.hadoop.hbase.consensus.quorum.AppendConsensusSession;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/IsCandidate.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/IsCandidate.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/IsCandidate.java
index 40d51b9..458d0bb 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/IsCandidate.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/IsCandidate.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.events;
 
+/*
+ * 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.
+ */
+
+
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 import org.apache.hadoop.hbase.consensus.fsm.Conditional;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/IsFollower.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/IsFollower.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/IsFollower.java
index 52b6e99..e61cf0e 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/IsFollower.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/IsFollower.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.events;
 
+/*
+ * 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.
+ */
+
+
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 import org.apache.hadoop.hbase.consensus.fsm.Conditional;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/IsLeader.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/IsLeader.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/IsLeader.java
index 3464976..88a6001 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/IsLeader.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/IsLeader.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.events;
 
+/*
+ * 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.
+ */
+
+
 
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/IsTransactionLogNotAccessible.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/IsTransactionLogNotAccessible.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/IsTransactionLogNotAccessible.java
index 1a905d1..80ef174 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/IsTransactionLogNotAccessible.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/IsTransactionLogNotAccessible.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.events;
 
+/*
+ * 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.
+ */
+
+
 import org.apache.hadoop.hbase.consensus.fsm.Conditional;
 import org.apache.hadoop.hbase.consensus.fsm.Event;
 import org.apache.hadoop.hbase.consensus.quorum.ImmutableRaftContext;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/NeedStepDown.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/NeedStepDown.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/NeedStepDown.java
index 73d7ace..46a8c39 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/NeedStepDown.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/NeedStepDown.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.events;
 
+/*
+ * 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.
+ */
+
+
 import org.apache.hadoop.hbase.consensus.fsm.Conditional;
 import org.apache.hadoop.hbase.consensus.fsm.Event;
 import org.apache.hadoop.hbase.consensus.quorum.AppendConsensusSession;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/NoQuorumMembershipChangeInProgress.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/NoQuorumMembershipChangeInProgress.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/NoQuorumMembershipChangeInProgress.java
index 3cf8515..cc8aa35 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/NoQuorumMembershipChangeInProgress.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/NoQuorumMembershipChangeInProgress.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.events;
 
+/*
+ * 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.
+ */
+
+
 import org.apache.hadoop.hbase.consensus.fsm.Conditional;
 import org.apache.hadoop.hbase.consensus.fsm.Event;
 import org.apache.hadoop.hbase.consensus.quorum.ImmutableRaftContext;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/ProgressTimeoutEvent.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/ProgressTimeoutEvent.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/ProgressTimeoutEvent.java
index 28ca257..b7fda2b 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/ProgressTimeoutEvent.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/ProgressTimeoutEvent.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.events;
 
+/*
+ * 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.
+ */
+
+
 import org.apache.hadoop.hbase.consensus.fsm.Event;
 
 public class ProgressTimeoutEvent extends Event {

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/QuorumMembershipChangeEvent.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/QuorumMembershipChangeEvent.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/QuorumMembershipChangeEvent.java
index 511030c..dc450fc 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/QuorumMembershipChangeEvent.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/QuorumMembershipChangeEvent.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.events;
 
+/*
+ * 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.
+ */
+
+
 import org.apache.hadoop.hbase.consensus.fsm.Event;
 import org.apache.hadoop.hbase.consensus.quorum.QuorumMembershipChangeRequest;
 

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/QuorumMembershipChangeInProgress.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/QuorumMembershipChangeInProgress.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/QuorumMembershipChangeInProgress.java
index 20b8857..5911f90 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/QuorumMembershipChangeInProgress.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/QuorumMembershipChangeInProgress.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.events;
 
+/*
+ * 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.
+ */
+
+
 import org.apache.hadoop.hbase.consensus.fsm.Conditional;
 import org.apache.hadoop.hbase.consensus.fsm.Event;
 import org.apache.hadoop.hbase.consensus.quorum.ImmutableRaftContext;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/RaftEventType.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/RaftEventType.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/RaftEventType.java
index 7d971a3..d428c0f 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/RaftEventType.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/RaftEventType.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.events;
 
+/*
+ * 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.
+ */
+
+
 import org.apache.hadoop.hbase.consensus.fsm.EventType;
 
 public enum RaftEventType implements EventType {

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/ReplicateEntriesEvent.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/ReplicateEntriesEvent.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/ReplicateEntriesEvent.java
index 0b8988d..79d9345 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/ReplicateEntriesEvent.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/ReplicateEntriesEvent.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.events;
 
+/*
+ * 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.
+ */
+
+
 import com.google.common.util.concurrent.SettableFuture;
 
 import org.apache.hadoop.hbase.consensus.protocol.Payload;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/ReseedRequestEvent.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/ReseedRequestEvent.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/ReseedRequestEvent.java
index 65f3907..9257e76 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/ReseedRequestEvent.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/ReseedRequestEvent.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.events;
 
+/*
+ * 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.
+ */
+
+
 import org.apache.hadoop.hbase.consensus.fsm.Event;
 import org.apache.hadoop.hbase.consensus.quorum.ReseedRequest;
 import org.apache.hadoop.hbase.ipc.thrift.exceptions.ThriftHBaseException;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/StartEvent.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/StartEvent.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/StartEvent.java
index f5f1792..1b569ab 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/StartEvent.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/StartEvent.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.events;
 
+/*
+ * 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.
+ */
+
+
 import org.apache.hadoop.hbase.consensus.fsm.Event;
 
 public class StartEvent extends Event {

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/VoteFailed.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/VoteFailed.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/VoteFailed.java
index e59e1ec..4f12689 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/VoteFailed.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/VoteFailed.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.events;
 
+/*
+ * 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.
+ */
+
+
 import org.apache.hadoop.hbase.consensus.fsm.Conditional;
 import org.apache.hadoop.hbase.consensus.fsm.Event;
 import org.apache.hadoop.hbase.consensus.quorum.*;