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:28 UTC

[3/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/raft/events/VoteNotCompleted.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/VoteNotCompleted.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/VoteNotCompleted.java
index ae9f336..174219c 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/VoteNotCompleted.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/VoteNotCompleted.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/VoteRequestEvent.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/VoteRequestEvent.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/VoteRequestEvent.java
index e990a6f..e5eb758 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/VoteRequestEvent.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/VoteRequestEvent.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.VoteRequest;
 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/VoteResponseEvent.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/VoteResponseEvent.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/VoteResponseEvent.java
index 786109e..e4e3400 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/VoteResponseEvent.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/VoteResponseEvent.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.VoteResponse;
 

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/VoteSucceeded.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/VoteSucceeded.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/VoteSucceeded.java
index 39e5d2f..7424f31 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/VoteSucceeded.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/events/VoteSucceeded.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.*;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/AckClient.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/AckClient.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/AckClient.java
index 0526060..aa260e2 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/AckClient.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/AckClient.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.states;
 
+/*
+ * 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/states/BecomeFollower.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/BecomeFollower.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/BecomeFollower.java
index ed2d509..1fb6fdf 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/BecomeFollower.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/BecomeFollower.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.states;
 
+/*
+ * 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.Event;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/BecomeLeader.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/BecomeLeader.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/BecomeLeader.java
index e2f13d2..d11a75b 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/BecomeLeader.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/BecomeLeader.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.states;
 
+/*
+ * 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.hbase.consensus.fsm.Event;
 import org.apache.hadoop.hbase.consensus.protocol.ConsensusHost;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/Candidate.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/Candidate.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/Candidate.java
index b2b7029..eaa612e 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/Candidate.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/Candidate.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.states;
 
+/*
+ * 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.Event;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/ChangeQuorumMembership.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/ChangeQuorumMembership.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/ChangeQuorumMembership.java
index 1a84bb5..fd57438 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/ChangeQuorumMembership.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/ChangeQuorumMembership.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.states;
 
+/*
+ * 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.util.Arrays;
 import java.util.List;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/Follower.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/Follower.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/Follower.java
index 89e9318..dafbf9a 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/Follower.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/Follower.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.states;
 
+/*
+ * 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.Event;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/Halt.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/Halt.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/Halt.java
index abab02c..72b070f 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/Halt.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/Halt.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.states;
 
+/*
+ * 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.rpc.PeerStatus;
 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/states/HandleAppendRequest.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/HandleAppendRequest.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/HandleAppendRequest.java
index 727fd66..b43bc17 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/HandleAppendRequest.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/HandleAppendRequest.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.states;
 
+/*
+ * 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.FutureCallback;
 import com.google.common.util.concurrent.Futures;
 import com.google.common.util.concurrent.ListenableFuture;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/HandleAppendResponse.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/HandleAppendResponse.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/HandleAppendResponse.java
index ce4da56..150d4cd 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/HandleAppendResponse.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/HandleAppendResponse.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.states;
 
+/*
+ * 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.protocol.EditId;
 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/states/HandleQuorumMembershipChangeRequest.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/HandleQuorumMembershipChangeRequest.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/HandleQuorumMembershipChangeRequest.java
index 2c627b1..ae881df 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/HandleQuorumMembershipChangeRequest.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/HandleQuorumMembershipChangeRequest.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.states;
 
+/*
+ * 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.MutableRaftContext;
 import org.apache.hadoop.hbase.consensus.quorum.QuorumInfo;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/HandleReseedRequest.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/HandleReseedRequest.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/HandleReseedRequest.java
index f1a152d..279d7bb 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/HandleReseedRequest.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/HandleReseedRequest.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.states;
 
+/*
+ * 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.ReseedRequest;
 import org.apache.hadoop.hbase.consensus.raft.events.ReseedRequestEvent;
 import org.slf4j.Logger;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/HandleVoteRequest.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/HandleVoteRequest.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/HandleVoteRequest.java
index 1e50e8b..6a54dc1 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/HandleVoteRequest.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/HandleVoteRequest.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.states;
 
+/*
+ * 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.protocol.ConsensusHost;
 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/raft/states/HandleVoteResponse.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/HandleVoteResponse.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/HandleVoteResponse.java
index ad9e38c..8a8c2dd 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/HandleVoteResponse.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/HandleVoteResponse.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.states;
 
+/*
+ * 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.VoteConsensusSessionInterface;
 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/states/Leader.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/Leader.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/Leader.java
index 02c1d2d..47535e7 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/Leader.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/Leader.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.states;
 
+/*
+ * 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.Event;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/ProgressTimeout.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/ProgressTimeout.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/ProgressTimeout.java
index 3b81623..31118d2 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/ProgressTimeout.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/ProgressTimeout.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.states;
 
+/*
+ * 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.Event;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/RaftAsyncState.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/RaftAsyncState.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/RaftAsyncState.java
index 9e0a9ba..6faa4c9 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/RaftAsyncState.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/RaftAsyncState.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.states;
 
+/*
+ * 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.MutableRaftContext;
 
 /**

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/RaftState.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/RaftState.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/RaftState.java
index 79df1a7..05f35ed 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/RaftState.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/RaftState.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.states;
 
+/*
+ * 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.Event;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/RaftStateType.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/RaftStateType.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/RaftStateType.java
index d4302d9..5c3e2f5 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/RaftStateType.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/RaftStateType.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.states;
 
+/*
+ * 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.StateType;
 
 public enum RaftStateType implements StateType {

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/ReSendAppendRequest.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/ReSendAppendRequest.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/ReSendAppendRequest.java
index ce71204..51ab332 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/ReSendAppendRequest.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/ReSendAppendRequest.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.states;
 
+/*
+ * 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/states/SendAppendRequest.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/SendAppendRequest.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/SendAppendRequest.java
index 19479e8..c687858 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/SendAppendRequest.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/SendAppendRequest.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.states;
 
+/*
+ * 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;
 import org.apache.hadoop.hbase.consensus.exceptions.LeaderNotReadyException;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/SendVoteRequest.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/SendVoteRequest.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/SendVoteRequest.java
index e2523d22..6f28dc5 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/SendVoteRequest.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/SendVoteRequest.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.states;
 
+/*
+ * 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.protocol.ConsensusHost;
 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/raft/states/Start.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/Start.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/Start.java
index 8422309..5313000 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/Start.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/states/Start.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.states;
 
+/*
+ * 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.Event;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/transitions/RaftTransitionType.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/transitions/RaftTransitionType.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/transitions/RaftTransitionType.java
index 9943dd6..6f5fb9b 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/transitions/RaftTransitionType.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/raft/transitions/RaftTransitionType.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.raft.transitions;
 
+/*
+ * 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.TransitionType;
 
 public enum RaftTransitionType implements TransitionType {

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/rpc/AppendRequest.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/rpc/AppendRequest.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/rpc/AppendRequest.java
index c2bd496..01700ba 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/rpc/AppendRequest.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/rpc/AppendRequest.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.rpc;
 
+/*
+ * 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/rpc/AppendResponse.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/rpc/AppendResponse.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/rpc/AppendResponse.java
index 8e7c1e0..9bb1d94 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/rpc/AppendResponse.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/rpc/AppendResponse.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.rpc;
 
+/*
+ * 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/rpc/LogState.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/rpc/LogState.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/rpc/LogState.java
index 0d2dae3..379824a 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/rpc/LogState.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/rpc/LogState.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.rpc;
 
+/*
+ * 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/rpc/PeerStatus.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/rpc/PeerStatus.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/rpc/PeerStatus.java
index cbd28ce..c3b9be5 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/rpc/PeerStatus.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/rpc/PeerStatus.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.rpc;
 
+/*
+ * 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.ThriftEnum;
 import com.facebook.swift.codec.ThriftField;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/rpc/Request.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/rpc/Request.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/rpc/Request.java
index a90af7b..529f56b 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/rpc/Request.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/rpc/Request.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.rpc;
 
+/*
+ * 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;
 
 public abstract class Request<T> {

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/rpc/VoteRequest.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/rpc/VoteRequest.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/rpc/VoteRequest.java
index bb7660a..4ed1800 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/rpc/VoteRequest.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/rpc/VoteRequest.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.rpc;
 
+/*
+ * 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 javax.annotation.concurrent.Immutable;
 
 import com.facebook.swift.codec.ThriftConstructor;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/rpc/VoteResponse.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/rpc/VoteResponse.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/rpc/VoteResponse.java
index 3986f3c..4eafe6a 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/rpc/VoteResponse.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/rpc/VoteResponse.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.rpc;
 
+/*
+ * 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/server/ConsensusService.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/ConsensusService.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/ConsensusService.java
index e061cc3..8bc0f0a 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/ConsensusService.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/ConsensusService.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.server;
 
+/*
+ * 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.service.ThriftException;
 import com.facebook.swift.service.ThriftMethod;
 import com.facebook.swift.service.ThriftService;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/ConsensusServiceImpl.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/ConsensusServiceImpl.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/ConsensusServiceImpl.java
index 6bb9eac..2376662 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/ConsensusServiceImpl.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/ConsensusServiceImpl.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.server;
 
+/*
+ * 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.collect.ImmutableMap;
 import com.google.common.util.concurrent.Futures;
 import com.google.common.util.concurrent.ListenableFuture;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/InstrumentedConsensusServiceImpl.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/InstrumentedConsensusServiceImpl.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/InstrumentedConsensusServiceImpl.java
index 7b10e7d..e93ad9e 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/InstrumentedConsensusServiceImpl.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/InstrumentedConsensusServiceImpl.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.server;
 
+/*
+ * 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.hbase.consensus.rpc.AppendRequest;
 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/server/LocalConsensusServer.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/LocalConsensusServer.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/LocalConsensusServer.java
index 777d917..8094b4c 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/LocalConsensusServer.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/LocalConsensusServer.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.server;
 
+/*
+ * 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.units.Duration;
 
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/AbstractPeer.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/AbstractPeer.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/AbstractPeer.java
index 23bc9d6..442f4d4 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/AbstractPeer.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/AbstractPeer.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.server.peer;
 
+/*
+ * 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.FutureCallback;
 import com.google.common.util.concurrent.Futures;
 import com.google.common.util.concurrent.ListenableFuture;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/PeerConsensusServer.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/PeerConsensusServer.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/PeerConsensusServer.java
index eb8003f..f1b7387 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/PeerConsensusServer.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/PeerConsensusServer.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.server.peer;
 
+/*
+ * 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.nifty.client.FramedClientConnector;
 import com.facebook.nifty.duplex.TDuplexProtocolFactory;
 import com.facebook.swift.service.ThriftClient;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/PeerServer.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/PeerServer.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/PeerServer.java
index 81dbd57..954de38 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/PeerServer.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/PeerServer.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.server.peer;
 
+/*
+ * 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.consensus.rpc.AppendRequest;
 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/server/peer/PeerServerImmutableContext.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/PeerServerImmutableContext.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/PeerServerImmutableContext.java
index 1f90a0c..a562628 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/PeerServerImmutableContext.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/PeerServerImmutableContext.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.server.peer;
 
+/*
+ * 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.AppendRequest;
 

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/PeerServerMutableContext.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/PeerServerMutableContext.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/PeerServerMutableContext.java
index e98a1e2..b37e865 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/PeerServerMutableContext.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/PeerServerMutableContext.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.server.peer;
 
+/*
+ * 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.PeerMetrics;
 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/server/peer/PeerStateMachine.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/PeerStateMachine.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/PeerStateMachine.java
index 90d3493..3630a27 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/PeerStateMachine.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/PeerStateMachine.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.server.peer;
 
+/*
+ * 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.server.peer.events.PeerServerEventType;
 import org.apache.hadoop.hbase.consensus.server.peer.states.*;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/ReconnectTimeoutCallback.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/ReconnectTimeoutCallback.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/ReconnectTimeoutCallback.java
index e6809a4..8289510 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/ReconnectTimeoutCallback.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/ReconnectTimeoutCallback.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.server.peer;
 
+/*
+ * 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.TimeoutEventHandler;
 import org.apache.hadoop.hbase.consensus.server.peer.events.PeerServerEventType;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/events/PeerAppendRequestEvent.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/events/PeerAppendRequestEvent.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/events/PeerAppendRequestEvent.java
index 0417feb..5554e0a 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/events/PeerAppendRequestEvent.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/events/PeerAppendRequestEvent.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.server.peer.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;
 

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/events/PeerAppendResponseEvent.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/events/PeerAppendResponseEvent.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/events/PeerAppendResponseEvent.java
index 410cd97..2c0ac2d 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/events/PeerAppendResponseEvent.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/events/PeerAppendResponseEvent.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.server.peer.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/server/peer/events/PeerServerEventType.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/events/PeerServerEventType.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/events/PeerServerEventType.java
index 23f68c4..2b4ada4 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/events/PeerServerEventType.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/events/PeerServerEventType.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.server.peer.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 PeerServerEventType implements EventType {

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/events/PeerVoteRequestEvent.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/events/PeerVoteRequestEvent.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/events/PeerVoteRequestEvent.java
index 43a90a0..697022c 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/events/PeerVoteRequestEvent.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/events/PeerVoteRequestEvent.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.server.peer.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.VoteRequest;
 

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/events/PeerVoteResponseEvent.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/events/PeerVoteResponseEvent.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/events/PeerVoteResponseEvent.java
index f5cf85c..04c43e5 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/events/PeerVoteResponseEvent.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/events/PeerVoteResponseEvent.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.server.peer.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.VoteResponse;
 

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/states/PeerFollower.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/states/PeerFollower.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/states/PeerFollower.java
index d32c471..16bb369 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/states/PeerFollower.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/states/PeerFollower.java
@@ -1,4 +1,24 @@
 package org.apache.hadoop.hbase.consensus.server.peer.states;
+
+/*
+ * 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.Event;

http://git-wip-us.apache.org/repos/asf/hbase/blob/8e7a91a3/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/states/PeerHandleAppendResponse.java
----------------------------------------------------------------------
diff --git a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/states/PeerHandleAppendResponse.java b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/states/PeerHandleAppendResponse.java
index 40205a5..523fe83 100644
--- a/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/states/PeerHandleAppendResponse.java
+++ b/hbase-consensus/src/main/java/org/apache/hadoop/hbase/consensus/server/peer/states/PeerHandleAppendResponse.java
@@ -1,5 +1,25 @@
 package org.apache.hadoop.hbase.consensus.server.peer.states;
 
+/*
+ * 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.ArrayList;