You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@helix.apache.org by ka...@apache.org on 2014/01/02 01:14:13 UTC

[13/31] Rearrange website directory structure

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/bea21020/website/0.7.0-incubating/src/site/markdown/tutorial_user_def_rebalancer.md
----------------------------------------------------------------------
diff --git a/website/0.7.0-incubating/src/site/markdown/tutorial_user_def_rebalancer.md b/website/0.7.0-incubating/src/site/markdown/tutorial_user_def_rebalancer.md
new file mode 100644
index 0000000..90577af
--- /dev/null
+++ b/website/0.7.0-incubating/src/site/markdown/tutorial_user_def_rebalancer.md
@@ -0,0 +1,227 @@
+<!---
+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.
+-->
+
+<head>
+  <title>Tutorial - User-Defined Rebalancing</title>
+</head>
+
+## [Helix Tutorial](./Tutorial.html): User-Defined Rebalancing
+
+Even though Helix can compute both the location and the state of replicas internally using a default fully-automatic rebalancer, specific applications may require rebalancing strategies that optimize for different requirements. Thus, Helix allows applications to plug in arbitrary rebalancer algorithms that implement a provided interface. One of the main design goals of Helix is to provide maximum flexibility to any distributed application. Thus, it allows applications to fully implement the rebalancer, which is the core constraint solver in the system, if the application developer so chooses.
+
+Whenever the state of the cluster changes, as is the case when participants join or leave the cluster, Helix automatically calls the rebalancer to compute a new mapping of all the replicas in the resource. When using a pluggable rebalancer, the only required step is to register it with Helix. Subsequently, no additional bootstrapping steps are necessary. Helix uses reflection to look up and load the class dynamically at runtime. As a result, it is also technically possible to change the rebalancing strategy used at any time.
+
+The [HelixRebalancer](http://helix.incubator.apache.org/javadocs/0.7.0-incubating/reference/org/apache/helix/controller/rebalancer/HelixRebalancer.html) interface is as follows:
+
+```
+public void init(HelixManager helixManager);
+
+public ResourceAssignment computeResourceMapping(RebalancerConfig rebalancerConfig, Cluster cluster,
+    ResourceCurrentState currentState);
+```
+The first parameter is a configuration of the resource to rebalance, the second is a full cache of all of the cluster data available to Helix, and the third is a snapshot of the actual current placements and state assignments. From the cluster variable, it is also possible to access the ResourceAssignment last generated by this rebalancer. Internally, Helix implements the same interface for its own rebalancing routines, so a user-defined rebalancer will be cognizant of the same information about the cluster as an internal implementation. Helix strives to provide applications the ability to implement algorithms that may require a large portion of the entire state of the cluster to make the best placement and state assignment decisions possible.
+
+A ResourceAssignment is a full representation of the location and the state of each replica of each partition of a given resource. This is a simple representation of the placement that the algorithm believes is the best possible. If the placement meets all defined constraints, this is what will become the actual state of the distributed system.
+
+### Rebalancer Context
+
+Helix provides an interface called [RebalancerContext](http://helix.incubator.apache.org/javadocs/0.7.0-incubating/reference/org/apache/helix/controller/rebalancer/context/RebalancerContext.html). For each of the four main [rebalancing modes](./tutorial_rebalance.html), there is a base class called [PartitionedRebalancerContext](http://helix.incubator.apache.org/javadocs/0.7.0-incubating/reference/org/apache/helix/controller/rebalancer/context/PartitionedRebalancerContext.html), which contains all of the basic properties required for a partitioned resource. Helix provides three derived classes for PartitionedRebalancerContext: FullAutoRebalancerContext, SemiAutoRebalancerContext, and CustomizedRebalancerContext. If none of these work for your application, you can create your own class that derives PartiitonedRebalancerContext (or even only implements RebalancerContext).
+
+### Specifying a Rebalancer
+
+#### Using Logical Accessors
+To specify the rebalancer, one can use ```PartitionedRebalancerContext#setRebalancerRef(RebalancerRef)``` to specify the specific implementation of the rebalancerClass. For example, here's a base constructed PartitionedRebalancerContext with a user-specified class:
+
+```
+RebalancerRef rebalancerRef = RebalancerRef.from(className);
+PartitionedRebalancerContext rebalanceContext =
+    new PartitionedRebalancerContext.Builder(resourceId).replicaCount(1).addPartition(partition1)
+        .addPartition(partition2).stateModelDefId(stateModelDef.getStateModelDefId())
+        .rebalancerRef(rebalancerRef).build();
+```
+
+The class name is a fully-qualified class name consisting of its package and its name, and the class should implement the Rebalancer interface. Now, the context can be added to a ResourceConfig through ```ResourceConfig.Builder#rebalancerContext(RebalancerContext)``` and the context will automatically be made available to the rebalancer for all subsequent executions.
+
+#### Using HelixAdmin
+For implementations that set up the cluster through existing code, the following HelixAdmin calls will update the Rebalancer class:
+
+```
+IdealState idealState = helixAdmin.getResourceIdealState(clusterName, resourceName);
+idealState.setRebalanceMode(RebalanceMode.USER_DEFINED);
+idealState.setRebalancerClassName(className);
+helixAdmin.setResourceIdealState(clusterName, resourceName, idealState);
+```
+There are two key fields to set to specify that a pluggable rebalancer should be used. First, the rebalance mode should be set to USER_DEFINED, and second the rebalancer class name should be set to a class that implements Rebalancer and is within the scope of the project. The class name is a fully-qualified class name consisting of its package and its name.
+
+#### Using YAML
+Alternatively, the rebalancer class name can be specified in a YAML file representing the cluster configuration. The requirements are the same, but the representation is more compact. Below are the first few lines of an example YAML file. To see a full YAML specification, see the [YAML tutorial](./tutorial_yaml.html).
+
+```
+clusterName: lock-manager-custom-rebalancer # unique name for the cluster
+resources:
+  - name: lock-group # unique resource name
+    rebalancer: # we will provide our own rebalancer
+      mode: USER_DEFINED
+      class: domain.project.helix.rebalancer.UserDefinedRebalancerClass
+...
+```
+
+### Example
+We demonstrate plugging in a simple user-defined rebalancer as part of a revisit of the [distributed lock manager](./recipes/user_def_rebalancer.html) example. It includes a functional Rebalancer implementation, as well as the entire YAML file used to define the cluster.
+
+Consider the case where partitions are locks in a lock manager and 6 locks are to be distributed evenly to a set of participants, and only one participant can hold each lock. We can define a rebalancing algorithm that simply takes the modulus of the lock number and the number of participants to evenly distribute the locks across participants. Helix allows capping the number of partitions a participant can accept, but since locks are lightweight, we do not need to define a restriction in this case. The following is a succinct implementation of this algorithm.
+
+```
+@Override
+public ResourceAssignment computeResourceMapping(RebalancerConfig rebalancerConfig, Cluster cluster,
+    ResourceCurrentState currentState) {
+  // Get the rebalcancer context (a basic partitioned one)
+  PartitionedRebalancerContext context = rebalancerConfig.getRebalancerContext(
+      PartitionedRebalancerContext.class);
+
+  // Initialize an empty mapping of locks to participants
+  ResourceAssignment assignment = new ResourceAssignment(context.getResourceId());
+
+  // Get the list of live participants in the cluster
+  List<ParticipantId> liveParticipants = new ArrayList<ParticipantId>(
+      cluster.getLiveParticipantMap().keySet());
+
+  // Get the state model (should be a simple lock/unlock model) and the highest-priority state
+  StateModelDefId stateModelDefId = context.getStateModelDefId();
+  StateModelDefinition stateModelDef = cluster.getStateModelMap().get(stateModelDefId);
+  if (stateModelDef.getStatesPriorityList().size() < 1) {
+    LOG.error("Invalid state model definition. There should be at least one state.");
+    return assignment;
+  }
+  State lockState = stateModelDef.getTypedStatesPriorityList().get(0);
+
+  // Count the number of participants allowed to lock each lock
+  String stateCount = stateModelDef.getNumParticipantsPerState(lockState);
+  int lockHolders = 0;
+  try {
+    // a numeric value is a custom-specified number of participants allowed to lock the lock
+    lockHolders = Integer.parseInt(stateCount);
+  } catch (NumberFormatException e) {
+    LOG.error("Invalid state model definition. The lock state does not have a valid count");
+    return assignment;
+  }
+
+  // Fairly assign the lock state to the participants using a simple mod-based sequential
+  // assignment. For instance, if each lock can be held by 3 participants, lock 0 would be held
+  // by participants (0, 1, 2), lock 1 would be held by (1, 2, 3), and so on, wrapping around the
+  // number of participants as necessary.
+  // This assumes a simple lock-unlock model where the only state of interest is which nodes have
+  // acquired each lock.
+  int i = 0;
+  for (PartitionId partition : context.getPartitionSet()) {
+    Map<ParticipantId, State> replicaMap = new HashMap<ParticipantId, State>();
+    for (int j = i; j < i + lockHolders; j++) {
+      int participantIndex = j % liveParticipants.size();
+      ParticipantId participant = liveParticipants.get(participantIndex);
+      // enforce that a participant can only have one instance of a given lock
+      if (!replicaMap.containsKey(participant)) {
+        replicaMap.put(participant, lockState);
+      }
+    }
+    assignment.addReplicaMap(partition, replicaMap);
+    i++;
+  }
+  return assignment;
+}
+```
+
+Here is the ResourceAssignment emitted by the user-defined rebalancer for a 3-participant system whenever there is a change to the set of participants.
+
+* Participant_A joins
+
+```
+{
+  "lock_0": { "Participant_A": "LOCKED"},
+  "lock_1": { "Participant_A": "LOCKED"},
+  "lock_2": { "Participant_A": "LOCKED"},
+  "lock_3": { "Participant_A": "LOCKED"},
+  "lock_4": { "Participant_A": "LOCKED"},
+  "lock_5": { "Participant_A": "LOCKED"},
+}
+```
+
+A ResourceAssignment is a mapping for each resource of partition to the participant serving each replica and the state of each replica. The state model is a simple LOCKED/RELEASED model, so participant A holds all lock partitions in the LOCKED state.
+
+* Participant_B joins
+
+```
+{
+  "lock_0": { "Participant_A": "LOCKED"},
+  "lock_1": { "Participant_B": "LOCKED"},
+  "lock_2": { "Participant_A": "LOCKED"},
+  "lock_3": { "Participant_B": "LOCKED"},
+  "lock_4": { "Participant_A": "LOCKED"},
+  "lock_5": { "Participant_B": "LOCKED"},
+}
+```
+
+Now that there are two participants, the simple mod-based function assigns every other lock to the second participant. On any system change, the rebalancer is invoked so that the application can define how to redistribute its resources.
+
+* Participant_C joins (steady state)
+
+```
+{
+  "lock_0": { "Participant_A": "LOCKED"},
+  "lock_1": { "Participant_B": "LOCKED"},
+  "lock_2": { "Participant_C": "LOCKED"},
+  "lock_3": { "Participant_A": "LOCKED"},
+  "lock_4": { "Participant_B": "LOCKED"},
+  "lock_5": { "Participant_C": "LOCKED"},
+}
+```
+
+This is the steady state of the system. Notice that four of the six locks now have a different owner. That is because of the naïve modulus-based assignmemt approach used by the user-defined rebalancer. However, the interface is flexible enough to allow you to employ consistent hashing or any other scheme if minimal movement is a system requirement.
+
+* Participant_B fails
+
+```
+{
+  "lock_0": { "Participant_A": "LOCKED"},
+  "lock_1": { "Participant_C": "LOCKED"},
+  "lock_2": { "Participant_A": "LOCKED"},
+  "lock_3": { "Participant_C": "LOCKED"},
+  "lock_4": { "Participant_A": "LOCKED"},
+  "lock_5": { "Participant_C": "LOCKED"},
+}
+```
+
+On any node failure, as in the case of node addition, the rebalancer is invoked automatically so that it can generate a new mapping as a response to the change. Helix ensures that the Rebalancer has the opportunity to reassign locks as required by the application.
+
+* Participant_B (or the replacement for the original Participant_B) rejoins
+
+```
+{
+  "lock_0": { "Participant_A": "LOCKED"},
+  "lock_1": { "Participant_B": "LOCKED"},
+  "lock_2": { "Participant_C": "LOCKED"},
+  "lock_3": { "Participant_A": "LOCKED"},
+  "lock_4": { "Participant_B": "LOCKED"},
+  "lock_5": { "Participant_C": "LOCKED"},
+}
+```
+
+The rebalancer was invoked once again and the resulting ResourceAssignment reflects the steady state.
+
+### Caveats
+- The rebalancer class must be available at runtime, or else Helix will not attempt to rebalance at all

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/bea21020/website/0.7.0-incubating/src/site/markdown/tutorial_yaml.md
----------------------------------------------------------------------
diff --git a/website/0.7.0-incubating/src/site/markdown/tutorial_yaml.md b/website/0.7.0-incubating/src/site/markdown/tutorial_yaml.md
new file mode 100644
index 0000000..4660afa
--- /dev/null
+++ b/website/0.7.0-incubating/src/site/markdown/tutorial_yaml.md
@@ -0,0 +1,102 @@
+<!---
+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.
+-->
+
+<head>
+  <title>Tutorial - YAML Cluster Setup</title>
+</head>
+
+## [Helix Tutorial](./Tutorial.html): YAML Cluster Setup
+
+As an alternative to using Helix Admin to set up the cluster, its resources, constraints, and the state model, Helix supports bootstrapping a cluster configuration based on a YAML file. Below is an annotated example of such a file for a simple distributed lock manager where a lock can only be LOCKED or RELEASED, and each lock only allows a single participant to hold it in the LOCKED state.
+
+```
+clusterName: lock-manager-custom-rebalancer # unique name for the cluster (required)
+resources:
+  - name: lock-group # unique resource name (required)
+    rebalancer: # required
+      mode: USER_DEFINED # required - USER_DEFINED means we will provide our own rebalancer
+      class: org.apache.helix.userdefinedrebalancer.LockManagerRebalancer # required for USER_DEFINED
+    partitions:
+      count: 12 # number of partitions for the resource (default is 1)
+      replicas: 1 # number of replicas per partition (default is 1)
+    stateModel:
+      name: lock-unlock # model name (required)
+      states: [LOCKED, RELEASED, DROPPED] # the list of possible states (required if model not built-in)
+      transitions: # the list of possible transitions (required if model not built-in)
+        - name: Unlock
+          from: LOCKED
+          to: RELEASED
+        - name: Lock
+          from: RELEASED
+          to: LOCKED
+        - name: DropLock
+          from: LOCKED
+          to: DROPPED
+        - name: DropUnlock
+          from: RELEASED
+          to: DROPPED
+        - name: Undrop
+          from: DROPPED
+          to: RELEASED
+      initialState: RELEASED # (required if model not built-in)
+    constraints:
+      state:
+        counts: # maximum number of replicas of a partition that can be in each state (required if model not built-in)
+          - name: LOCKED
+            count: "1"
+          - name: RELEASED
+            count: "-1"
+          - name: DROPPED
+            count: "-1"
+        priorityList: [LOCKED, RELEASED, DROPPED] # states in order of priority (all priorities equal if not specified)
+      transition: # transitions priority to enforce order that transitions occur
+        priorityList: [Unlock, Lock, Undrop, DropUnlock, DropLock] # all priorities equal if not specified
+participants: # list of nodes that can serve replicas (optional if dynamic joining is active, required otherwise)
+  - name: localhost_12001
+    host: localhost
+    port: 12001
+  - name: localhost_12002
+    host: localhost
+    port: 12002
+  - name: localhost_12003
+    host: localhost
+    port: 12003
+```
+
+Using a file like the one above, the cluster can be set up either with the command line:
+
+```
+incubator-helix/helix-core/target/helix-core/pkg/bin/YAMLClusterSetup.sh localhost:2199 lock-manager-config.yaml
+```
+
+or with code:
+
+```
+YAMLClusterSetup setup = new YAMLClusterSetup(zkAddress);
+InputStream input =
+    Thread.currentThread().getContextClassLoader()
+        .getResourceAsStream("lock-manager-config.yaml");
+YAMLClusterSetup.YAMLClusterConfig config = setup.setupCluster(input);
+```
+
+Some notes:
+
+- A rebalancer class is only required for the USER_DEFINED mode. It is ignored otherwise.
+
+- Built-in state models, like OnlineOffline, LeaderStandby, and MasterSlave, or state models that have already been added only require a name for stateModel. If partition and/or replica counts are not provided, a value of 1 is assumed.

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/bea21020/website/0.7.0-incubating/src/site/resources/.htaccess
----------------------------------------------------------------------
diff --git a/website/0.7.0-incubating/src/site/resources/.htaccess b/website/0.7.0-incubating/src/site/resources/.htaccess
new file mode 100644
index 0000000..d5c7bf3
--- /dev/null
+++ b/website/0.7.0-incubating/src/site/resources/.htaccess
@@ -0,0 +1,20 @@
+#
+# 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.
+#
+
+Redirect /download.html /download.cgi

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/bea21020/website/0.7.0-incubating/src/site/resources/download.cgi
----------------------------------------------------------------------
diff --git a/website/0.7.0-incubating/src/site/resources/download.cgi b/website/0.7.0-incubating/src/site/resources/download.cgi
new file mode 100644
index 0000000..f9a0e30
--- /dev/null
+++ b/website/0.7.0-incubating/src/site/resources/download.cgi
@@ -0,0 +1,22 @@
+#!/bin/sh
+# Just call the standard mirrors.cgi script. It will use download.html
+# as the input template.
+#
+# 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.
+#
+exec /www/www.apache.org/dyn/mirrors/mirrors.cgi $*

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/bea21020/website/0.7.0-incubating/src/site/resources/images/PFS-Generic.png
----------------------------------------------------------------------
diff --git a/website/0.7.0-incubating/src/site/resources/images/PFS-Generic.png b/website/0.7.0-incubating/src/site/resources/images/PFS-Generic.png
new file mode 100644
index 0000000..7eea3a0
Binary files /dev/null and b/website/0.7.0-incubating/src/site/resources/images/PFS-Generic.png differ

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/bea21020/website/0.7.0-incubating/src/site/resources/images/RSYNC_BASED_PFS.png
----------------------------------------------------------------------
diff --git a/website/0.7.0-incubating/src/site/resources/images/RSYNC_BASED_PFS.png b/website/0.7.0-incubating/src/site/resources/images/RSYNC_BASED_PFS.png
new file mode 100644
index 0000000..0cc55ae
Binary files /dev/null and b/website/0.7.0-incubating/src/site/resources/images/RSYNC_BASED_PFS.png differ

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/bea21020/website/0.7.0-incubating/src/site/site.xml
----------------------------------------------------------------------
diff --git a/website/0.7.0-incubating/src/site/site.xml b/website/0.7.0-incubating/src/site/site.xml
new file mode 100644
index 0000000..8ba455d
--- /dev/null
+++ b/website/0.7.0-incubating/src/site/site.xml
@@ -0,0 +1,141 @@
+<?xml version="1.0" encoding="ISO-8859-1"?>
+<!--
+  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.
+-->
+<project name="Apache Helix">
+  <bannerLeft>
+    <src>../images/helix-logo.jpg</src>
+    <href>http://helix.incubator.apache.org/</href>
+  </bannerLeft>
+  <bannerRight>
+    <src>../images/feather_small.gif</src>
+    <href>http://www.apache.org/</href>
+  </bannerRight>
+  <version position="none"/>
+
+  <publishDate position="right"/>
+
+  <skin>
+    <groupId>lt.velykis.maven.skins</groupId>
+    <artifactId>reflow-maven-skin</artifactId>
+    <version>1.0.0</version>
+  </skin>
+
+  <body>
+
+    <head>
+      <script type="text/javascript">
+
+        var _gaq = _gaq || [];
+        _gaq.push(['_setAccount', 'UA-3211522-12']);
+        _gaq.push(['_trackPageview']);
+
+        (function() {
+        var ga = document.createElement('script'); ga.type = 'text/javascript'; ga.async = true;
+        ga.src = ('https:' == document.location.protocol ? 'https://ssl' : 'http://www') + '.google-analytics.com/ga.js';
+        var s = document.getElementsByTagName('script')[0]; s.parentNode.insertBefore(ga, s);
+        })();
+
+      </script>
+
+    </head>
+
+    <breadcrumbs position="left">
+      <item name="Apache Helix" href="http://helix.incubator.apache.org/"/>
+      <item name="Release 0.7.0-incubating" href="http://helix.incubator.apache.org/0.7.0-incubating-docs/"/>
+    </breadcrumbs>
+
+    <links>
+      <item name="Helix 0.7.0-incubating" href="./index.html"/>
+    </links>
+
+    <menu name="Get Helix">
+      <item name="Download" href="./download.html"/>
+      <item name="Building" href="./Building.html"/>
+      <item name="Release Notes" href="./releasenotes/release-0.7.0-incubating.html"/>
+    </menu>
+
+    <menu name="Hands-On">
+      <item name="Quick Start" href="./Quickstart.html"/>
+      <item name="Tutorial" href="./Tutorial.html"/>
+      <item name="Javadocs" href="http://helix.incubator.apache.org/javadocs/0.7.0-incubating"/>
+    </menu>
+
+    <menu name="Recipes">
+      <item name="Distributed lock manager" href="./recipes/lock_manager.html"/>
+      <item name="Rabbit MQ consumer group" href="./recipes/rabbitmq_consumer_group.html"/>
+      <item name="Rsync replicated file store" href="./recipes/rsync_replicated_file_store.html"/>
+      <item name="Service Discovery" href="./recipes/service_discovery.html"/>
+      <item name="Distributed task DAG Execution" href="./recipes/task_dag_execution.html"/>
+      <item name="User-defined rebalancer" href="./recipes/user_def_rebalancer.html"/>
+    </menu>
+<!--
+    <menu ref="reports" inherit="bottom"/>
+    <menu ref="modules" inherit="bottom"/>
+
+
+    <menu name="ASF">
+      <item name="How Apache Works" href="http://www.apache.org/foundation/how-it-works.html"/>
+      <item name="Foundation" href="http://www.apache.org/foundation/"/>
+      <item name="Sponsoring Apache" href="http://www.apache.org/foundation/sponsorship.html"/>
+      <item name="Thanks" href="http://www.apache.org/foundation/thanks.html"/>
+    </menu>
+-->
+    <footer>
+      <div class="row span16"><div>Apache Helix, Apache, the Apache feather logo, and the Apache Helix project logos are trademarks of The Apache Software Foundation.
+        All other marks mentioned may be trademarks or registered trademarks of their respective owners.</div>
+        <a href="${project.url}/privacy-policy.html">Privacy Policy</a>
+      </div>
+    </footer>
+
+
+  </body>
+
+  <custom>
+    <reflowSkin>
+      <theme>default</theme>
+      <highlightJs>false</highlightJs>
+      <brand>
+        <name>Apache Helix</name>
+        <href>http://helix.incubator.apache.org</href>
+      </brand>
+      <slogan>A cluster management framework for partitioned and replicated distributed resources</slogan>
+      <bottomNav>
+        <column>Get Helix</column>
+        <column>Hands-On</column>
+        <column>Recipes</column>
+      </bottomNav>
+      <pages>
+        <index>
+          <sections>
+            <columns>3</columns>
+          </sections>
+        </index>
+      </pages>
+    </reflowSkin>
+    <!--fluidoSkin>
+      <topBarEnabled>true</topBarEnabled>
+      <sideBarEnabled>true</sideBarEnabled>
+      <googleSearch></googleSearch>
+      <twitter>
+        <user>ApacheHelix</user>
+        <showUser>true</showUser>
+        <showFollowers>false</showFollowers>
+      </twitter>
+    </fluidoSkin-->
+  </custom>
+
+</project>

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/bea21020/website/0.7.0-incubating/src/site/xdoc/download.xml.vm
----------------------------------------------------------------------
diff --git a/website/0.7.0-incubating/src/site/xdoc/download.xml.vm b/website/0.7.0-incubating/src/site/xdoc/download.xml.vm
new file mode 100644
index 0000000..6949719
--- /dev/null
+++ b/website/0.7.0-incubating/src/site/xdoc/download.xml.vm
@@ -0,0 +1,213 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+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.
+
+-->
+#set( $releaseName = "0.7.0-incubating" )
+#set( $releaseDate = "11/22/2013" )
+<document xmlns="http://maven.apache.org/XDOC/2.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+          xsi:schemaLocation="http://maven.apache.org/XDOC/2.0 http://maven.apache.org/xsd/xdoc-2.0.xsd">
+
+  <properties>
+    <title>Apache Helix Downloads</title>
+    <author email="dev@helix.incubator.apache.org">Apache Helix Documentation Team</author>
+  </properties>
+
+  <body>
+    <div class="toc_container">
+      <macro name="toc">
+        <param name="class" value="toc"/>
+      </macro>
+    </div>
+
+    <section name="Introduction">
+      <p>Apache Helix artifacts are distributed in source and binary form under the terms of the
+        <a href="http://www.apache.org/licenses/LICENSE-2.0">Apache License, Version 2.0</a>.
+        See the included <tt>LICENSE</tt> and <tt>NOTICE</tt> files included in each artifact for additional license
+        information.
+      </p>
+      <p>Use the links below to download a source distribution of Apache Helix.
+      It is good practice to <a href="#Verifying_Releases">verify the integrity</a> of the distribution files.</p>
+    </section>
+
+    <section name="Release">
+      <p>Release date: ${releaseDate} </p>
+      <p><a href="releasenotes/release-${releaseName}.html">${releaseName} Release notes</a></p>
+      <a name="mirror"/>
+      <subsection name="Mirror">
+
+        <p>
+          [if-any logo]
+          <a href="[link]">
+            <img align="right" src="[logo]" border="0"
+                 alt="logo"/>
+          </a>
+          [end]
+          The currently selected mirror is
+          <b>[preferred]</b>.
+          If you encounter a problem with this mirror,
+          please select another mirror.
+          If all mirrors are failing, there are
+          <i>backup</i>
+          mirrors
+          (at the end of the mirrors list) that should be available.
+        </p>
+
+        <form action="[location]" method="get" id="SelectMirror" class="form-inline">
+          Other mirrors:
+          <select name="Preferred" class="input-xlarge">
+            [if-any http]
+            [for http]
+            <option value="[http]">[http]</option>
+            [end]
+            [end]
+            [if-any ftp]
+            [for ftp]
+            <option value="[ftp]">[ftp]</option>
+            [end]
+            [end]
+            [if-any backup]
+            [for backup]
+            <option value="[backup]">[backup] (backup)</option>
+            [end]
+            [end]
+          </select>
+          <input type="submit" value="Change" class="btn"/>
+        </form>
+
+        <p>
+          You may also consult the
+          <a href="http://www.apache.org/mirrors/">complete list of mirrors.</a>
+        </p>
+
+      </subsection>
+      <subsection name="${releaseName} Sources">
+        <table>
+          <thead>
+            <tr>
+              <th>Artifact</th>
+              <th>Signatures</th>
+            </tr>
+          </thead>
+          <tbody>
+            <tr>
+              <td>
+                <a href="[preferred]incubator/helix/${releaseName}/src/helix-${releaseName}-src.zip">helix-${releaseName}-src.zip</a>
+              </td>
+              <td>
+                <a href="http://www.apache.org/dist/incubator/helix/${releaseName}/src/helix-${releaseName}-src.zip.asc">asc</a>
+                <a href="http://www.apache.org/dist/incubator/helix/${releaseName}/src/helix-${releaseName}-src.zip.md5">md5</a>
+                <a href="http://www.apache.org/dist/incubator/helix/${releaseName}/src/helix-${releaseName}-src.zip.sha1">sha1</a>
+              </td>
+            </tr>
+          </tbody>
+        </table>
+      </subsection>
+      <subsection name="${releaseName} Binaries">
+        <table>
+          <thead>
+            <tr>
+              <th>Artifact</th>
+              <th>Signatures</th>
+            </tr>
+          </thead>
+          <tbody>
+            <tr>
+              <td>
+                <a href="[preferred]incubator/helix/${releaseName}/binaries/helix-core-${releaseName}-pkg.tar">helix-core-${releaseName}-pkg.tar</a>
+              </td>
+              <td>
+                <a href="http://www.apache.org/dist/incubator/helix/${releaseName}/binaries/helix-core-${releaseName}-pkg.tar.asc">asc</a>
+                <a href="http://www.apache.org/dist/incubator/helix/${releaseName}/binaries/helix-core-${releaseName}-pkg.tar.md5">md5</a>
+                <a href="http://www.apache.org/dist/incubator/helix/${releaseName}/binaries/helix-core-${releaseName}-pkg.tar.sha1">sha1</a>
+              </td>
+            </tr>
+            <tr>
+              <td>
+                <a href="[preferred]incubator/helix/${releaseName}/binaries/helix-admin-webapp-${releaseName}-pkg.tar">helix-admin-webapp-${releaseName}-pkg.tar</a>
+              </td>
+              <td>
+                <a href="http://www.apache.org/dist/incubator/helix/${releaseName}/binaries/helix-admin-webapp-${releaseName}-pkg.tar.asc">asc</a>
+                <a href="http://www.apache.org/dist/incubator/helix/${releaseName}/binaries/helix-admin-webapp-${releaseName}-pkg.tar.md5">md5</a>
+                <a href="http://www.apache.org/dist/incubator/helix/${releaseName}/binaries/helix-admin-webapp-${releaseName}-pkg.tar.sha1">sha1</a>
+              </td>
+            </tr>
+            <tr>
+              <td>
+                <a href="[preferred]incubator/helix/${releaseName}/binaries/helix-agent-${releaseName}-pkg.tar">helix-agent-${releaseName}-pkg.tar</a>
+              </td>
+              <td>
+                <a href="http://www.apache.org/dist/incubator/helix/${releaseName}/binaries/helix-agent-${releaseName}-pkg.tar.asc">asc</a>
+                <a href="http://www.apache.org/dist/incubator/helix/${releaseName}/binaries/helix-agent-${releaseName}-pkg.tar.md5">md5</a>
+                <a href="http://www.apache.org/dist/incubator/helix/${releaseName}/binaries/helix-agent-${releaseName}-pkg.tar.sha1">sha1</a>
+              </td>
+            </tr>
+            <tr>
+              <td>
+                <a href="[preferred]incubator/helix/${releaseName}/binaries/helix-examples-${releaseName}-pkg.tar">helix-examples-${releaseName}-pkg.tar</a>
+              </td>
+              <td>
+                <a href="http://www.apache.org/dist/incubator/helix/${releaseName}/binaries/helix-examples-${releaseName}-pkg.tar.asc">asc</a>
+                <a href="http://www.apache.org/dist/incubator/helix/${releaseName}/binaries/helix-examples-${releaseName}-pkg.tar.md5">md5</a>
+                <a href="http://www.apache.org/dist/incubator/helix/${releaseName}/binaries/helix-examples-${releaseName}-pkg.tar.sha1">sha1</a>
+              </td>
+            </tr>
+          </tbody>
+        </table>
+      </subsection>
+    </section>
+
+<!--    <section name="Older Releases">
+    </section>-->
+
+    <section name="Verifying Releases">
+      <p>We strongly recommend you verify the integrity of the downloaded files with both PGP and MD5.</p>
+
+      <p>The PGP signatures can be verified using <a href="http://www.pgpi.org/">PGP</a> or
+      <a href="http://www.gnupg.org/">GPG</a>.
+      First download the <a href="http://www.apache.org/dist/incubator/helix/KEYS">KEYS</a> as well as the
+      <tt>*.asc</tt> signature file for the particular distribution. Make sure you get these files from the main
+      distribution directory, rather than from a mirror. Then verify the signatures using one of the following sets of
+      commands:
+
+        <source>$ pgp -ka KEYS
+$ pgp helix-*.zip.asc</source>
+
+        <source>$ gpg --import KEYS
+$ gpg --verify helix-*.zip.asc</source>
+       </p>
+    <p>Alternatively, you can verify the MD5 signature on the files. A Unix/Linux program called
+      <code>md5</code> or
+      <code>md5sum</code> is included in most distributions.  It is also available as part of
+      <a href="http://www.gnu.org/software/textutils/textutils.html">GNU Textutils</a>.
+      Windows users can get binary md5 programs from these (and likely other) places:
+      <ul>
+        <li>
+          <a href="http://www.md5summer.org/">http://www.md5summer.org/</a>
+        </li>
+        <li>
+          <a href="http://www.fourmilab.ch/md5/">http://www.fourmilab.ch/md5/</a>
+        </li>
+        <li>
+          <a href="http://www.pc-tools.net/win32/md5sums/">http://www.pc-tools.net/win32/md5sums/</a>
+        </li>
+      </ul>
+    </p>
+    </section>
+  </body>
+</document>

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/bea21020/website/0.7.0-incubating/src/test/conf/testng.xml
----------------------------------------------------------------------
diff --git a/website/0.7.0-incubating/src/test/conf/testng.xml b/website/0.7.0-incubating/src/test/conf/testng.xml
new file mode 100644
index 0000000..58f0803
--- /dev/null
+++ b/website/0.7.0-incubating/src/test/conf/testng.xml
@@ -0,0 +1,27 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+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.
+-->
+<!DOCTYPE suite SYSTEM "http://testng.org/testng-1.0.dtd">
+<suite name="Suite" parallel="none">
+  <test name="Test" preserve-order="false">
+    <packages>
+      <package name="org.apache.helix"/>
+    </packages>
+  </test>
+</suite>

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/bea21020/website/deploySite.sh
----------------------------------------------------------------------
diff --git a/website/deploySite.sh b/website/deploySite.sh
new file mode 100755
index 0000000..47d685f
--- /dev/null
+++ b/website/deploySite.sh
@@ -0,0 +1,24 @@
+#!/bin/sh
+
+#
+# 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.
+#
+read -s -p "Enter Apache Username: " myusername
+echo ""
+read -s -p "Enter Apache Password: " mypassword
+mvn clean site-deploy scm-publish:publish-scm -Dusername="$myusername" -Dpassword="$mypassword" -DskipTests $@

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/bea21020/website/pom.xml
----------------------------------------------------------------------
diff --git a/website/pom.xml b/website/pom.xml
new file mode 100644
index 0000000..8368775
--- /dev/null
+++ b/website/pom.xml
@@ -0,0 +1,122 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+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.
+-->
+<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
+  <parent>
+    <groupId>org.apache.helix</groupId>
+    <artifactId>helix</artifactId>
+    <version>0.7.1-incubating-SNAPSHOT</version>
+  </parent>
+  <modelVersion>4.0.0</modelVersion>
+  <packaging>pom</packaging>
+
+  <artifactId>website</artifactId>
+  <name>Apache Helix :: Website</name>
+
+  <url>http://helix.incubator.apache.org</url>
+
+  <modules>
+    <module>0.6.1-incubating</module>
+    <module>0.6.2-incubating</module>
+    <module>0.7.0-incubating</module>
+    <module>trunk</module>
+  </modules>
+
+  <properties>
+    <helix.siteFilePath>${user.home}/helix-site/helix-site-deploy</helix.siteFilePath>
+    <helix.siteUrlDeployment>file://${helix.siteFilePath}</helix.siteUrlDeployment>
+    <helix.scmPubCheckoutDirectory>${user.home}/helix-site/helix-site-content</helix.scmPubCheckoutDirectory>
+    <scmSkipDeletedFiles>false</scmSkipDeletedFiles>
+  </properties>
+
+  <distributionManagement>
+    <site>
+      <id>apache.website</id>
+      <url>${helix.siteUrlDeployment}</url>
+    </site>
+  </distributionManagement>
+
+  <dependencies>
+  </dependencies>
+  <build>
+    <resources>
+    </resources>
+    <plugins>
+      <plugin>
+        <groupId>org.apache.maven.plugins</groupId>
+        <artifactId>maven-site-plugin</artifactId>
+        <version>3.3</version>
+        <dependencies>
+          <dependency>
+            <groupId>lt.velykis.maven.skins</groupId>
+            <artifactId>reflow-velocity-tools</artifactId>
+            <version>1.0.0</version>
+          </dependency>
+          <dependency>
+            <groupId>org.apache.velocity</groupId>
+            <artifactId>velocity</artifactId>
+            <version>1.7</version>
+          </dependency>
+          <dependency>
+            <groupId>org.apache.maven.doxia</groupId>
+            <artifactId>doxia-module-markdown</artifactId>
+            <version>1.3</version>
+          </dependency>
+        </dependencies>
+      </plugin>
+    </plugins>
+    <pluginManagement>
+      <plugins>
+        <plugin>
+          <groupId>org.apache.maven.plugins</groupId>
+          <artifactId>maven-scm-publish-plugin</artifactId>
+          <version>1.0-beta-2</version>
+          <configuration>
+            <tryUpdate>true</tryUpdate>
+            <providerImplementations>
+              <svn>${svnImpl}</svn>
+            </providerImplementations>
+            <pubScmUrl>scm:svn:https://svn.apache.org/repos/asf/incubator/helix/site-content/</pubScmUrl>
+            <content>${helix.siteFilePath}</content>
+            <checkoutDirectory>${helix.scmPubCheckoutDirectory}</checkoutDirectory>
+            <skipDeletedFiles>${scmSkipDeletedFiles}</skipDeletedFiles>
+            <ignorePathsToDelete>
+              <ignorePathToDelete>javadocs</ignorePathToDelete>
+              <ignorePathToDelete>javadocs**</ignorePathToDelete>
+              <ignorePathToDelete>apidocs</ignorePathToDelete>
+              <ignorePathToDelete>apidocs**</ignorePathToDelete>
+            </ignorePathsToDelete>
+          </configuration>
+          <dependencies>
+            <dependency>
+              <groupId>com.google.code.maven-scm-provider-svnjava</groupId>
+              <artifactId>maven-scm-provider-svnjava</artifactId>
+              <version>${maven-scm-provider-svnjava.version}</version>
+            </dependency>
+            <dependency>
+              <groupId>org.tmatesoft.svnkit</groupId>
+              <artifactId>svnkit</artifactId>
+              <version>${svnkit.version}</version>
+            </dependency>
+          </dependencies>
+        </plugin>
+      </plugins>
+    </pluginManagement>
+  </build>
+</project>

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/bea21020/website/src/site/apt/privacy-policy.apt
----------------------------------------------------------------------
diff --git a/website/src/site/apt/privacy-policy.apt b/website/src/site/apt/privacy-policy.apt
new file mode 100644
index 0000000..ada9363
--- /dev/null
+++ b/website/src/site/apt/privacy-policy.apt
@@ -0,0 +1,52 @@
+ ----
+ Privacy Policy
+ -----
+ Olivier Lamy
+ -----
+ 2013-02-04
+ -----
+
+~~ 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.
+
+Privacy Policy
+
+  Information about your use of this website is collected using server access logs and a tracking cookie. The 
+  collected information consists of the following:
+
+  [[1]] The IP address from which you access the website;
+  
+  [[2]] The type of browser and operating system you use to access our site;
+  
+  [[3]] The date and time you access our site;
+  
+  [[4]] The pages you visit; and
+  
+  [[5]] The addresses of pages from where you followed a link to our site.
+
+  []
+
+  Part of this information is gathered using a tracking cookie set by the 
+  {{{http://www.google.com/analytics/}Google Analytics}} service and handled by Google as described in their 
+  {{{http://www.google.com/privacy.html}privacy policy}}. See your browser documentation for instructions on how to 
+  disable the cookie if you prefer not to share this data with Google.
+
+  We use the gathered information to help us make our site more useful to visitors and to better understand how and 
+  when our site is used. We do not track or collect personally identifiable information or associate gathered data 
+  with any personally identifying information from other sources.
+
+  By using this website, you consent to the collection of this data in the manner and for the purpose described above.

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/bea21020/website/src/site/apt/releasenotes/release-0.6.0-incubating.apt
----------------------------------------------------------------------
diff --git a/website/src/site/apt/releasenotes/release-0.6.0-incubating.apt b/website/src/site/apt/releasenotes/release-0.6.0-incubating.apt
new file mode 100644
index 0000000..16e2fbf
--- /dev/null
+++ b/website/src/site/apt/releasenotes/release-0.6.0-incubating.apt
@@ -0,0 +1,77 @@
+ -----
+ Release Notes for 0.6.0-incubating Apache Helix
+ -----
+
+~~ 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.
+
+~~ NOTE: For help with the syntax of this file, see:
+~~ http://maven.apache.org/guides/mini/guide-apt-format.html
+
+Release Notes for 0.6.0-incubating Apache Helix
+
+  The Apache Helix would like to announce the release of Apache Helix 0.6.0-incubating
+
+  This is the first release in Apache umbrella.
+
+  Helix is a generic cluster management framework used for the automatic management of partitioned, replicated and distributed resources hosted on a cluster of nodes. Helix provides the following features:
+
+  * Automatic assignment of resource/partition to nodes
+
+  * Node failure detection and recovery
+
+  * Dynamic addition of Resources
+
+  * Dynamic addition of nodes to the cluster
+
+  * Pluggable distributed state machine to manage the state of a resource via state transitions
+
+  * Automatic load balancing and throttling of transitions
+
+  []
+
+* Changes
+
+** Bug
+
+ * [HELIX-1] - Use org.apache.helix package for java sources.
+
+ * [HELIX-2] - Remove jsqlparser dependency from Helix
+
+ * [HELIX-3] - Fix license headers in sources.
+
+ * [HELIX-12] - Issue with starting multiple controllers with same name
+ 
+ * [HELIX-14] - error in helix-core ivy file
+
+ []
+
+** Task
+
+  * [HELIX-4] - Remove deprecated file based implementation
+
+  * [HELIX-5] - Remove deprecated Accessors
+
+  * [HELIX-13] - New usecase to replicate files between replicas using simple rsync
+
+  * [HELIX-15] - Distributed lock manager recipe
+
+  []
+
+  Have Fun
+  --
+  The Apache Helix Team

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/bea21020/website/src/site/apt/releasenotes/release-0.6.1-incubating.apt
----------------------------------------------------------------------
diff --git a/website/src/site/apt/releasenotes/release-0.6.1-incubating.apt b/website/src/site/apt/releasenotes/release-0.6.1-incubating.apt
new file mode 100644
index 0000000..9305214
--- /dev/null
+++ b/website/src/site/apt/releasenotes/release-0.6.1-incubating.apt
@@ -0,0 +1,110 @@
+ -----
+ Release Notes for 0.6.1-incubating Apache Helix
+ -----
+
+~~ 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.
+
+~~ NOTE: For help with the syntax of this file, see:
+~~ http://maven.apache.org/guides/mini/guide-apt-format.html
+
+Release Notes for 0.6.1-incubating Apache Helix
+
+  The Apache Helix would like to announce the release of Apache Helix 0.6.1-incubating
+
+  This is the second release in Apache umbrella.
+
+  Helix is a generic cluster management framework used for the automatic management of partitioned, replicated and distributed resources hosted on a cluster of nodes. Helix provides the following features:
+
+  * Automatic assignment of resource/partition to nodes
+
+  * Node failure detection and recovery
+
+  * Dynamic addition of Resources
+
+  * Dynamic addition of nodes to the cluster
+
+  * Pluggable distributed state machine to manage the state of a resource via state transitions
+
+  * Automatic load balancing and throttling of transitions
+
+  []
+
+* Changes
+
+** Bug
+
+ * [HELIX-25] - setConfig should check if instance exist or not when setting PARTICIPANT config
+ 
+ * [HELIX-29] - Not receiving transitions after participant reconnection
+
+ * [HELIX-30] - ZkHelixManager.carryOverPreviousCurrentState() should use a special merge logic
+
+ * [HELIX-34] - Remove watches after the node /resource is deleted
+
+ * [HELIX-35] - Support custom instance id format in CLI
+
+ * [HELIX-41] - fix intermittent test failures
+
+ * [HELIX-44] - ZkHelix property store is not checking the validity of path
+
+ * [HELIX-55] - Session timeout setting not honoured
+
+ * [HELIX-75] - ZKHelixManager declares throws Exception
+
+ * [HELIX-76] - ChangeLogGenerator split bug
+
+
+** Improvements
+
+ * [HELIX-31] - Detect flapping and disable the participant/controller/spectator
+
+ * [HELIX-32] - Flapping detection: if a helix manager starts connect/disconnect frequently it should be disconnected
+
+ * [HELIX-64] - Allow application to provide additional metadata while connecting to cluster
+
+ * [HELIX-73] - Remove assumption that Instance.id is always host_port
+
+ * [HELIX-81] - org.apache.helix.manager.zk.ZKUtil#isClusterSetup() should not log error
+
+
+** New Features
+
+ * [HELIX-19] - Allow process to join the cluster dynamically
+
+ * [HELIX-43] - Add support for error->dropped transition
+
+ * [HELIX-45] - Standalone helix agent
+
+ * [HELIX-63] - Make the idealstate computation code pluggable
+
+ * [HELIX-72] - Allow pluggable rebalancer in controller
+
+
+** Tasks
+
+ * [HELIX-16] - Distributed task execution framework sample app
+
+
+  []
+
+  Cheers,
+  --
+  The Apache Helix Team
+
+
+

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/bea21020/website/src/site/apt/releasenotes/release-0.6.2-incubating.apt
----------------------------------------------------------------------
diff --git a/website/src/site/apt/releasenotes/release-0.6.2-incubating.apt b/website/src/site/apt/releasenotes/release-0.6.2-incubating.apt
new file mode 100644
index 0000000..51afc62
--- /dev/null
+++ b/website/src/site/apt/releasenotes/release-0.6.2-incubating.apt
@@ -0,0 +1,181 @@
+ -----
+ Release Notes for Apache Helix 0.6.2-incubating
+ -----
+
+~~ 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.
+
+~~ NOTE: For help with the syntax of this file, see:
+~~ http://maven.apache.org/guides/mini/guide-apt-format.html
+
+Release Notes for Apache Helix 0.6.2-incubating
+
+  The Apache Helix team would like to announce the release of Apache Helix 0.6.2-incubating
+
+  This is the third release under the Apache umbrella.
+
+  Helix is a generic cluster management framework used for the automatic management of partitioned, replicated and distributed resources hosted on a cluster of nodes. Helix provides the following features:
+
+  * Automatic assignment of resource/partition to nodes
+
+  * Node failure detection and recovery
+
+  * Dynamic addition of Resources
+
+  * Dynamic addition of nodes to the cluster
+
+  * Pluggable distributed state machine to manage the state of a resource via state transitions
+
+  * Automatic load balancing and throttling of transitions
+
+  []
+
+* Changes
+
+** Sub-task
+
+  * [HELIX-28] - ZkHelixManager.handleNewSession() can happen when a liveinstance already exists
+
+  * [HELIX-85] - Remove mock service module
+
+  * [HELIX-106] - Remove all string constants in the code
+
+  * [HELIX-107] - Add support to set custom objects into ZNRecord
+
+  * [HELIX-124] - race condition in ZkHelixManager.handleNewSession()
+
+  * [HELIX-165] - Add dependency for Guava libraries
+
+  * [HELIX-169] - Take care of consecutive handleNewSession() and session expiry during handleNewSession() 
+
+  * [HELIX-170] - HelixManager#isLeader() should compare both instanceName and sessionId 
+
+  * [HELIX-195] - Race condition between FINALIZE callbacks and Zk Callbacks
+
+  * [HELIX-207] - Add javadocs to classes and public methods in the top-level package
+
+  * [HELIX-208] - Add javadocs to classes and public methods in the model package
+
+  * [HELIX-277] - FULL_AUTO rebalancer should not prefer nodes that are just coming up
+
+** Bug
+
+  * [HELIX-7] - Tune test parameters to fix random test failures
+
+  * [HELIX-87] - Bad repository links in website
+
+  * [HELIX-117] - backward incompatibility problem in accessing zkPath vis HelixWebAdmin
+
+  * [HELIX-118] - PropertyStore -> HelixPropertyStore backwards incompatible location
+
+  * [HELIX-119] - HelixManager serializer no longer needs ByteArraySerializer for /PROPERTYSTORE
+
+  * [HELIX-129] - ZKDumper should use byte[] instead of String to read/write file/zk
+
+  * [HELIX-131] - Connection timeout not set while connecting to zookeeper via zkHelixAdmin
+
+  * [HELIX-133] - Cluster-admin command parsing does not work with removeConfig
+
+  * [HELIX-140] - In ClusterSetup.java, the removeConfig is wrong wired to getConfig
+
+  * [HELIX-141] - Autorebalance does not work reliably and fails when replica>1
+
+  * [HELIX-144] - Need to validate StateModelDefinition when adding new StateModelDefinition to Cluster
+
+  * [HELIX-147] - Fix typo in Idealstate property max_partitions_per_instance
+
+  * [HELIX-148] - Current preferred placement for auto rebalace is suboptimal for n > p
+
+  * [HELIX-150] - Auto rebalance might not evenly distribute states across nodes
+
+  * [HELIX-151] - Auto rebalance doesn't assign some replicas when other nodes could make room
+
+  * [HELIX-153] - Auto rebalance tester uses the returned map fields, but production uses only list fields
+
+  * [HELIX-155] - PropertyKey.instances() is wrongly wired to CONFIG type instead of INSTANCES type
+
+  * [HELIX-197] - state model leak
+
+  * [HELIX-199] - ZNRecord should not publish rawPayload unless it exists
+
+  * [HELIX-216] - Allow HelixAdmin addResource to accept the old rebalancing types
+
+  * [HELIX-221] - Can't find default error->dropped transition method using name convention
+
+  * [HELIX-257] - Upgrade Restlet to 2.1.4 - due security flaw
+
+  * [HELIX-258] - Upgrade Apache Camel due to CVE-2013-4330
+
+  * [HELIX-264] - fix zkclient#close() bug
+
+  * [HELIX-279] - Apply gc handling fixes to main ZKHelixManager class
+
+  * [HELIX-280] - Full auto rebalancer should check for resource tag first
+
+  * [HELIX-288] - helix-core uses an old version of guava
+
+  * [HELIX-299] - Some files in 0.6.2 are missing license headers
+
+** Improvement
+
+  * [HELIX-20] - AUTO-REBALANCE helix controller should re-assign disabled partitions on a node to other available nodes
+
+  * [HELIX-70] - Make Helix OSGi ready
+
+  * [HELIX-149] - Allow clients to pass in preferred placement strategies
+
+  * [HELIX-198] - Unify helix code style
+
+  * [HELIX-218] - Add a reviewboard submission script
+
+  * [HELIX-284] - Support participant auto join in YAML cluster setup
+
+** New Feature
+
+  * [HELIX-215] - Allow setting up the cluster with a YAML file
+
+** Task
+
+  * [HELIX-95] - Tracker for 0.6.2 release
+
+  * [HELIX-154] - Auto rebalance algorithm should not depend on state
+
+  * [HELIX-166] - Rename modes to auto, semi-auto, and custom
+
+  * [HELIX-173] - Move rebalancing strategies to separate classes that implement the Rebalancer interface
+
+  * [HELIX-188] - Add admin command line / REST API documentations
+
+  * [HELIX-194] - ZNRecord has too many constructors
+
+  * [HELIX-205] - Have user-defined rebalancers use RebalanceMode.USER_DEFINED
+
+  * [HELIX-210] - Add support to set data with expect version in BaseDataAccessor
+
+  * [HELIX-217] - Remove mock service module
+
+  * [HELIX-273] - Rebalancer interface should remain unchanged in 0.6.2
+
+  * [HELIX-274] - Verify FULL_AUTO tagged node behavior
+
+  * [HELIX-285] - add integration test util's
+
+  []
+
+  Cheers,
+  --
+  The Apache Helix Team

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/bea21020/website/src/site/apt/releasenotes/release-0.7.0-incubating.apt
----------------------------------------------------------------------
diff --git a/website/src/site/apt/releasenotes/release-0.7.0-incubating.apt b/website/src/site/apt/releasenotes/release-0.7.0-incubating.apt
new file mode 100644
index 0000000..7661df0
--- /dev/null
+++ b/website/src/site/apt/releasenotes/release-0.7.0-incubating.apt
@@ -0,0 +1,174 @@
+ -----
+ Release Notes for Apache Helix 0.7.0-incubating
+ -----
+
+~~ 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.
+
+~~ NOTE: For help with the syntax of this file, see:
+~~ http://maven.apache.org/guides/mini/guide-apt-format.html
+
+Release Notes for Apache Helix 0.7.0-incubating
+
+  The Apache Helix team would like to announce the release of Apache Helix 0.7.0-incubating
+
+  This is the fourth release and second major release under the Apache umbrella.
+
+  Helix is a generic cluster management framework used for the automatic management of partitioned, replicated and distributed resources hosted on a cluster of nodes. Helix provides the following features:
+
+  * Automatic assignment of resource/partition to nodes
+
+  * Node failure detection and recovery
+
+  * Dynamic addition of Resources
+
+  * Dynamic addition of nodes to the cluster
+
+  * Pluggable distributed state machine to manage the state of a resource via state transitions
+
+  * Automatic load balancing and throttling of transitions
+
+  * Configurable, pluggable rebalancing
+
+  []
+
+* Changes
+
+** Sub-task
+
+    * [HELIX-18] - Unify cluster setup and helixadmin
+
+    * [HELIX-79] - consecutive GC may mess up helix session ids
+
+    * [HELIX-83] - Add typed classes to denote helix ids
+
+    * [HELIX-90] - Clean up Api's
+
+    * [HELIX-98] - clean up setting constraint api
+
+    * [HELIX-100] - Improve the helix config api
+
+    * [HELIX-102] - Add new wrapper classes for Participant, Controller, Spectator, Administrator
+
+    * [HELIX-104] - Add support to reuse zkclient
+
+    * [HELIX-123] - ZkHelixManager.isLeader() should check session id in addition to instance name
+
+    * [HELIX-139] - Need to double check the logic to prevent 2 controllers to control the same cluster
+
+    * [HELIX-168] - separate HelixManager implementation for participant, controller, and distributed controller
+
+    * [HELIX-176] - Need a list of tests that must pass to certify a release
+
+    * [HELIX-224] - Move helix examples to separate module
+
+    * [HELIX-233] - Ensure that website and wiki fully capture the updated changes in 0.7.0
+
+    * [HELIX-234] - Create concrete id classes for constructs, replacing strings
+
+    * [HELIX-235] - Create a hierarchical logical model for the cluster
+
+    * [HELIX-236] - Create a hierarchical cluster snapshot to replace ClusterDataCache
+
+    * [HELIX-237] - Create helix-internal config classes for the hierarchical model
+
+    * [HELIX-238] - Create accessors for the logical model
+
+    * [HELIX-239] - List use cases for the logical model
+
+    * [HELIX-240] - Write an example of the key use cases for the logical model
+
+    * [HELIX-241] - Write the controller pipeline with the logical model
+
+    * [HELIX-242] - Re-integrate the scheduler rebalancing into the new controller pipeline
+
+    * [HELIX-243] - Fix failing tests related to helix model overhaul
+
+    * [HELIX-244] - Redesign rebalancers using rebalancer-specific configs
+
+    * [HELIX-246] - Refactor scheduler task config to comply with new rebalancer config and fix related scheduler task tests
+
+    * [HELIX-248] - Resource logical model should be general enough to handle various resource types
+
+    * [HELIX-268] - Atomic API
+
+    * [HELIX-297] - Make 0.7.0 backward compatible for user-defined rebalancing
+
+
+** Bug
+
+    * [HELIX-40] - fix zkclient subscribe path leaking and zk callback-handler leaking in case of session expiry
+
+    * [HELIX-46] - Add REST/cli admin command for message selection constraints
+
+    * [HELIX-47] - when drop resource, remove resource-level config also
+
+    * [HELIX-48] - use resource instead of db in output messages
+
+    * [HELIX-50] - Ensure num replicas and preference list size in idealstate matches
+
+    * [HELIX-59] - controller not cleaning dead external view generated from old sessions
+
+    * [HELIX-136] - Write IdealState back to ZK when computed by custom Rebalancer
+
+    * [HELIX-200] - helix controller send ERROR->DROPPED transition infinitely
+
+    * [HELIX-214] - User-defined rebalancer should never use SEMI_AUTO code paths
+
+    * [HELIX-225] - fix helix-example package build error
+
+    * [HELIX-271] - ZkHelixAdmin#addResource() backward compatible problem
+
+    * [HELIX-292] - ZNRecordStreamingSerializer should not assume id comes first
+
+    * [HELIX-296] - HelixConnection in 0.7.0 does not remove LiveInstance znode
+
+    * [HELIX-300] - Some files in 0.7.0 are missing license headers
+
+    * [HELIX-302] - fix helix version compare bug
+
+** Improvement
+
+    * [HELIX-37] - Cleanup CallbackHandler
+
+    * [HELIX-202] - Ideal state should be a full mapping, not just a set of instance preferences
+
+** Task
+
+    * [HELIX-109] - Review Helix model package
+
+    * [HELIX-174] - Clean up ideal state calculators, move them to the controller rebalancer package
+
+    * [HELIX-212] - Rebalancer interface should have 1 function to compute the entire ideal state
+
+    * [HELIX-232] - Validation of 0.7.0
+
+    * [HELIX-290] - Ensure 0.7.0 can respond correctly to ideal state changes
+
+    * [HELIX-295] - Upgrade or remove xstream dependency
+
+    * [HELIX-301] - Update integration test utils for 0.7.0
+
+** Test
+
+    * [HELIX-286] - add a test for redefine state model definition
+
+  []
+
+  Cheers,
+  --
+  The Apache Helix Team

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/bea21020/website/src/site/apt/releasing.apt
----------------------------------------------------------------------
diff --git a/website/src/site/apt/releasing.apt b/website/src/site/apt/releasing.apt
new file mode 100644
index 0000000..72cea5a
--- /dev/null
+++ b/website/src/site/apt/releasing.apt
@@ -0,0 +1,284 @@
+ -----
+ Helix Release Process
+ -----
+ -----
+ 2012-12-15
+ -----
+
+~~ 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.
+
+~~ NOTE: For help with the syntax of this file, see:
+~~ http://maven.apache.org/guides/mini/guide-apt-format.html
+
+Helix Release Process
+
+ [[1]] Post to dev@helix.incubator.apache.org a few days before you plan to do a Helix release
+
+ [[2]] Your Maven settings must contain this entry to be able to deploy.
+
+ ~/.m2/settings.xml
+
++-------------
+<server>
+  <id>apache.releases.https</id>
+  <username>[USERNAME]</username>
+  <password>[PASSWORD]</password>
+</server>
++-------------
+
+ [[3]] Apache DAV passwords
+
++-------------
+ Add the following info into your ~/.netrc
+ machine git-wip-us.apache.org login <apache username> <password>
+
++-------------
+ [[4]] Release Helix
+
+    You should have a GPG agent running in the session you will run the maven release commands (preferred), and confirm it works by running "gpg -ab" (type some text and press Ctrl-D).
+    If you do not have a GPG agent running, make sure that you have the "apache-release" profile set in your settings.xml as shown below.
+
+
+  GPG configuration in maven settings xml:
+
++-------------
+<profile>
+  <id>apache-release</id>
+  <properties>
+    <gpg.passphrase>[GPG_PASSWORD]</gpg.passphrase>
+  </properties>
+</profile>
++-------------
+
+   Run the release
+
++-------------
+mvn release:prepare
+mvn release:perform
++-------------
+
+ [[5]] Go to https://repository.apache.org and close your staged repository. Log in, click on Staging Repositories, check your repository, and click Close. Note the repository url (format https://repository.apache.org/content/repositories/orgapachehelix-[NNN]/org/apache/helix/helix/[VERSION]-incubating/)
+
+ [[6]] Stage the release (stagingRepoUrl format https://repository.apache.org/content/repositories/orgapachehelix-[NNN]/org/apache/helix/helix/[VERSION]-incubating/)
+
++-------------
+svn co https://dist.apache.org/repos/dist/dev/incubator/helix helix-dev-release
+cd helix-dev-release
+sh ./release-script-svn.sh version stagingRepoUrl
+svn add <new directory created with new version as name>
+gpg -k email@domain.com >> KEYS
+gpg --armor --export email@domain.com >> KEYS
+svn ci
++-------------
+
+ [[7]] Validate the release
+
++-------------
+  * Download sources, extract, build and run tests - mvn clean package
+  * Verify license headers - mvn -Prat -DskipTests
+  * Download binaries and .asc files
+  * Download release manager's public key - From the KEYS file, get the release manager's public key finger print and run  gpg --keyserver pgpkeys.mit.edu --recv-key <key>
+  * Validate authenticity of key - run  gpg --fingerprint <key>
+  * Check signatures of all the binaries using gpg <binary>
++-------------
+
+ [[8]] Call for a vote in the dev list and wait for 72 hours for the vote results.
+
++-------------
+Subject: [VOTE] Apache Helix [VERSION]-incubating Release
+To: dev@helix.incubator.apache.org
+---------------------------------------------------------
+Hi, I'd like to release Apache Helix [VERSION]-incubating.
+
+Release notes: http://helix.incubator.apache.org/releasenotes/release-[VERSION]-incubating.html
+
+Maven staged release repository: https://repository.apache.org/content/repositories/orgapachehelix-[NNN]/
+
+Distribution:
+* binaries: https://dist.apache.org/repos/dist/dev/incubator/helix/[VERSION]-incubating/binaries/
+* sources: https://dist.apache.org/repos/dist/dev/incubator/helix/[VERSION]-incubating/src/
+
+KEYS file available here: https://dist.apache.org/repos/dist/release/incubator/helix/KEYS
+
+Vote open for 72H
+
+[+1]
+[0]
+[-1]
++-------------
+
+ [[9]] If there are no objections, send the following email. Otherwise, repeat the previous step.
+
++-------------
+Subject: [RESULT][VOTE] Apache Helix [VERSION]-incubating Release
+To: dev@helix.incubator.apache.org
+-----------------------------------------------------------------
+Thanks for voting on the 0.6.2-incubating release. It has now exceeded 72 hours so I am closing the vote.
+
+Binding +1s:
+ [Names of IPMC members (i.e. mentors) who +1'd this release]
+
+Nonbinding +1s:
+ [All other +1s]
+
+Binding 0s:
+ [Names of IPMC members (i.e. mentors) who 0'd this release]
+
+Nonbinding 0s:
+ [All other 0s]
+
+Binding -1s:
+ [Names of IPMC members (i.e. mentors) who -1'd this release]
+
+Nonbinding -1s:
+ [All other -1s]
+
+I will now start a vote on the general incubator list, as that is the next step in the release approval process.
++-------------
+
+ [[10]] Open a vote on the general incubator mailing list. A total of 3 IPMC +1s are required for the release to be approved. This total can include the IPMC members who voted +1 in the previous vote.
+
++-------------
+Subject: [VOTE] Apache Helix [VERSION]-incubating Release
+To: general@incubator.apache.org
+---------------------------------------------------------
+Hi,
+
+This is to call for a vote on releasing the following candidate as Apache
+Helix [VERSION]-incubating. This is the first release candidate of our third
+release at Apache.
+
+Apache Helix is a generic cluster management framework that makes it easy
+to build partitioned and replicated, fault tolerant and scalable
+distributed systems.
+
+Release notes:
+http://helix.incubator.apache.org/[VERSION]-incubating-docs/releasenotes/release-[VERSION]-incubating.html
+
+Our vote thread on helix-dev:
+http://markmail.org/message/[MESSAGE ID]
+
+The following IPMC members have voted +1
+[IPMC members who voted +1 in the previous voting round]
+
+Release artifacts:
+https://repository.apache.org/content/repositories/orgapachehelix-[NNN]
+
+Distribution:
+* binaries:
+https://dist.apache.org/repos/dist/dev/incubator/helix/[VERSION]-incubating/binaries/
+* sources:
+https://dist.apache.org/repos/dist/dev/incubator/helix/[VERSION]-incubating/src/
+
+The 0.6.2-incubating release tag
+https://git-wip-us.apache.org/repos/asf?p=incubator-helix.git;a=tag;h=[TAG HASH]
+
+KEYS file available here:
+https://dist.apache.org/repos/dist/dev/incubator/helix/KEYS
+
+Please vote on the release. The vote will be open for 72 hours.
+
+[+1]
+[0]
+[-1]
+
+Thanks,
+The Apache Helix Team
++-------------
+
+ [[11]] After 72 hours, if the sum of IPMC members who have voted +1 in the two rounds of voting is at least 3, close the vote with the following email.
+
++-------------
+Subject: [RESULT][VOTE] Apache Helix [VERSION]-incubating Release
+To: general@incubator.apache.org
+-----------------------------------------------------------------
+Hi:
+
+Closing the vote since it has passed 72 hours.
+
+Here is the result:
+
++1: [NNN] (binding)
+[IPMC members who voted +1]
+
+0: [NNN] (binding)
+[IPMC members who voted 0]
+
+-1: [NNN] (binding)
+[IPMC members who voted -1]
+
+The vote has passed, thanks a lot to everyone for voting, Thanks to the
+mentors for all the support!
+
+Cheers,
+The Helix Team
++-------------
+
+ [[12]] Move the keys, sources, and binaries from the dev tree to the release tree:
+
++-------------
+svn rm https://dist.apache.org/repos/dist/release/incubator/helix/KEYS
+svn mv https://dist.apache.org/repos/dist/dev/incubator/helix/[VERSION]-incubating https://dist.apache.org/repos/dist/release/incubator/helix
+svn mv https://dist.apache.org/repos/dist/dev/incubator/helix/KEYS https://dist.apache.org/repos/dist/release/incubator/helix
++-------------
+
+ [[13]] Go to https://repository.apache.org and release your staged repository. Log in, click on Staging Repositories, check your repository, and click Release.
+
+ [[14]] Prepare release notes. Add a page in src/site/apt/releasenotes/ and [VERSION]-incubating/apt/releasenotes and change the value of \<currentRelease\> in parent pom.
+
+
+ [[15]] Send out an announcement of the release to Helix developers and users:
+
++-------------
+Subject: [ANNOUNCE] Apache Helix [VERSION]-incubating Release
+To: dev@helix.incubator.apache.org; user@helix.incubator.apache.org
+-------------------------------------------------------------------
+The Apache Helix Team is pleased to announce the [NTH] release,
+[VERSION]-incubating, of the Apache Helix project.
+
+Apache Helix is a generic cluster management framework that makes it easy
+to build partitioned, fault tolerant, and scalable distributed systems.
+
+The full release notes are available here:
+http://helix.incubator.apache.org/releasenotes/release-[VERSION]-incubating.html
+
+You can declare a maven dependency to use it:
+
+<dependency>
+  <groupId>org.apache.helix</groupId>
+  <artifactId>helix-core</artifactId>
+  <version>[VERSION]-incubating</version>
+</dependency>
+
+Or download the release sources:
+http://helix.incubator.apache.org/[VERSION]-incubating-docs/download.cgi
+
+Additional info
+
+Website: http://helix.incubator.apache.org/
+Helix mailing lists: http://helix.incubator.apache.org/mail-lists.html
+
+We hope you will enjoy using the latest release of Apache Helix!
+
+Cheers,
+Apache Helix Team
++-------------
+
+ [[16]] Celebrate!
+
+