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 22:53:01 UTC

[16/24] [HELIX-348] Simplify website layout

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/439125ae/site-releases/0.7.0-incubating/src/site/markdown/tutorial_state.md
----------------------------------------------------------------------
diff --git a/site-releases/0.7.0-incubating/src/site/markdown/tutorial_state.md b/site-releases/0.7.0-incubating/src/site/markdown/tutorial_state.md
deleted file mode 100644
index 4f7b1b5..0000000
--- a/site-releases/0.7.0-incubating/src/site/markdown/tutorial_state.md
+++ /dev/null
@@ -1,131 +0,0 @@
-<!---
-Licensed to the Apache Software Foundation (ASF) under one
-or more contributor license agreements.  See the NOTICE file
-distributed with this work for additional information
-regarding copyright ownership.  The ASF licenses this file
-to you under the Apache License, Version 2.0 (the
-"License"); you may not use this file except in compliance
-with the License.  You may obtain a copy of the License at
-
-  http://www.apache.org/licenses/LICENSE-2.0
-
-Unless required by applicable law or agreed to in writing,
-software distributed under the License is distributed on an
-"AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-KIND, either express or implied.  See the License for the
-specific language governing permissions and limitations
-under the License.
--->
-
-<head>
-  <title>Tutorial - State Machine Configuration</title>
-</head>
-
-# [Helix Tutorial](./Tutorial.html): State Machine Configuration
-
-In this chapter, we\'ll learn about the state models provided by Helix, and how to create your own custom state model.
-
-## State Models
-
-Helix comes with 3 default state models that are commonly used.  It is possible to have multiple state models in a cluster. 
-Every resource that is added should be configured to use a state model that govern its _ideal state_.
-
-### MASTER-SLAVE
-
-* 3 states: OFFLINE, SLAVE, MASTER
-* Maximum number of masters: 1
-* Slaves are based on the replication factor. The replication factor can be specified while adding the resource.
-
-
-### ONLINE-OFFLINE
-
-* Has 2 states: OFFLINE and ONLINE.  This simple state model is a good starting point for most applications.
-
-### LEADER-STANDBY
-
-* 1 Leader and multiple stand-bys.  The idea is that exactly one leader accomplishes a designated task, the stand-bys are ready to take over if the leader fails.
-
-## Constraints
-
-In addition to the state machine configuration, one can specify the constraints of states and transitions.
-
-For example, one can say:
-
-* MASTER:1
-<br/>Maximum number of replicas in MASTER state at any time is 1
-
-* OFFLINE-SLAVE:5 
-<br/>Maximum number of OFFLINE-SLAVE transitions that can happen concurrently in the system is 5 in this example.
-
-### Dynamic State Constraints
-
-We also support two dynamic upper bounds for the number of replicas in each state:
-
-* N: The number of replicas in the state is at most the number of live participants in the cluster
-* R: The number of replicas in the state is at most the specified replica count for the partition
-
-### State Priority
-
-Helix uses a greedy approach to satisfy the state constraints. For example, if the state machine configuration says it needs 1 MASTER and 2 SLAVES, but only 1 node is active, Helix must promote it to MASTER. This behavior is achieved by providing the state priority list as \[MASTER, SLAVE\].
-
-### State Transition Priority
-
-Helix tries to fire as many transitions as possible in parallel to reach the stable state without violating constraints. By default, Helix simply sorts the transitions alphabetically and fires as many as it can without violating the constraints. You can control this by overriding the priority order.
-
-## Special States
-
-### DROPPED
-
-The DROPPED state is used to signify a replica that was served by a given participant, but is no longer served. This allows Helix and its participants to effectively clean up. There are two requirements that every new state model should follow with respect to the DROPPED state:
-
-* The DROPPED state must be defined
-* There must be a path to DROPPED for every state in the model
-
-### ERROR
-
-The ERROR state is used whenever the participant serving a partition encountered an error and cannot continue to serve the partition. HelixAdmin has \"reset\" functionality to allow for participants to recover from the ERROR state.
-
-## Annotated Example
-
-Below is a complete definition of a Master-Slave state model. Notice the fields marked REQUIRED; these are essential for any state model definition.
-
-```
-StateModelDefinition stateModel = new StateModelDefinition.Builder("MasterSlave")
-  // OFFLINE is the state that the system starts in (initial state is REQUIRED)
-  .initialState("OFFLINE")
-
-  // Lowest number here indicates highest priority, no value indicates lowest priority
-  .addState("MASTER", 1)
-  .addState("SLAVE", 2)
-  .addState("OFFLINE")
-
-  // Note the special inclusion of the DROPPED state (REQUIRED)
-  .addState(HelixDefinedState.DROPPED.toString())
-
-  // No more than one master allowed
-  .upperBound("MASTER", 1)
-
-  // R indicates an upper bound of number of replicas for each partition
-  .dynamicUpperBound("SLAVE", "R")
-
-  // Add some high-priority transitions
-  .addTransition("SLAVE", "MASTER", 1)
-  .addTransition("OFFLINE", "SLAVE", 2)
-
-  // Using the same priority value indicates that these transitions can fire in any order
-  .addTransition("MASTER", "SLAVE", 3)
-  .addTransition("SLAVE", "OFFLINE", 3)
-
-  // Not specifying a value defaults to lowest priority
-  // Notice the inclusion of the OFFLINE to DROPPED transition
-  // Since every state has a path to OFFLINE, they each now have a path to DROPPED (REQUIRED)
-  .addTransition("OFFLINE", HelixDefinedState.DROPPED.toString())
-
-  // Create the StateModelDefinition instance
-  .build();
-
-  // Use the isValid() function to make sure the StateModelDefinition will work without issues
-  Assert.assertTrue(stateModel.isValid());
-```
-
-

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/439125ae/site-releases/0.7.0-incubating/src/site/markdown/tutorial_throttling.md
----------------------------------------------------------------------
diff --git a/site-releases/0.7.0-incubating/src/site/markdown/tutorial_throttling.md b/site-releases/0.7.0-incubating/src/site/markdown/tutorial_throttling.md
deleted file mode 100644
index 7417979..0000000
--- a/site-releases/0.7.0-incubating/src/site/markdown/tutorial_throttling.md
+++ /dev/null
@@ -1,38 +0,0 @@
-<!---
-Licensed to the Apache Software Foundation (ASF) under one
-or more contributor license agreements.  See the NOTICE file
-distributed with this work for additional information
-regarding copyright ownership.  The ASF licenses this file
-to you under the Apache License, Version 2.0 (the
-"License"); you may not use this file except in compliance
-with the License.  You may obtain a copy of the License at
-
-  http://www.apache.org/licenses/LICENSE-2.0
-
-Unless required by applicable law or agreed to in writing,
-software distributed under the License is distributed on an
-"AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-KIND, either express or implied.  See the License for the
-specific language governing permissions and limitations
-under the License.
--->
-
-<head>
-  <title>Tutorial - Throttling</title>
-</head>
-
-# [Helix Tutorial](./Tutorial.html): Throttling
-
-In this chapter, we\'ll learn how to control the parallel execution of cluster tasks.  Only a centralized cluster manager with global knowledge is capable of coordinating this decision.
-
-### Throttling
-
-Since all state changes in the system are triggered through transitions, Helix can control the number of transitions that can happen in parallel. Some of the transitions may be light weight, but some might involve moving data, which is quite expensive from a network and IOPS perspective.
-
-Helix allows applications to set a threshold on transitions. The threshold can be set at multiple scopes:
-
-* MessageType e.g STATE_TRANSITION
-* TransitionType e.g SLAVE-MASTER
-* Resource e.g database
-* Node i.e per-node maximum transitions in parallel
-

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/439125ae/site-releases/0.7.0-incubating/src/site/markdown/tutorial_user_def_rebalancer.md
----------------------------------------------------------------------
diff --git a/site-releases/0.7.0-incubating/src/site/markdown/tutorial_user_def_rebalancer.md b/site-releases/0.7.0-incubating/src/site/markdown/tutorial_user_def_rebalancer.md
deleted file mode 100644
index f30aafc..0000000
--- a/site-releases/0.7.0-incubating/src/site/markdown/tutorial_user_def_rebalancer.md
+++ /dev/null
@@ -1,227 +0,0 @@
-<!---
-Licensed to the Apache Software Foundation (ASF) under one
-or more contributor license agreements.  See the NOTICE file
-distributed with this work for additional information
-regarding copyright ownership.  The ASF licenses this file
-to you under the Apache License, Version 2.0 (the
-"License"); you may not use this file except in compliance
-with the License.  You may obtain a copy of the License at
-
-  http://www.apache.org/licenses/LICENSE-2.0
-
-Unless required by applicable law or agreed to in writing,
-software distributed under the License is distributed on an
-"AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-KIND, either express or implied.  See the License for the
-specific language governing permissions and limitations
-under the License.
--->
-
-<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
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/439125ae/site-releases/0.7.0-incubating/src/site/markdown/tutorial_yaml.md
----------------------------------------------------------------------
diff --git a/site-releases/0.7.0-incubating/src/site/markdown/tutorial_yaml.md b/site-releases/0.7.0-incubating/src/site/markdown/tutorial_yaml.md
deleted file mode 100644
index 0f8e0cc..0000000
--- a/site-releases/0.7.0-incubating/src/site/markdown/tutorial_yaml.md
+++ /dev/null
@@ -1,102 +0,0 @@
-<!---
-Licensed to the Apache Software Foundation (ASF) under one
-or more contributor license agreements.  See the NOTICE file
-distributed with this work for additional information
-regarding copyright ownership.  The ASF licenses this file
-to you under the Apache License, Version 2.0 (the
-"License"); you may not use this file except in compliance
-with the License.  You may obtain a copy of the License at
-
-  http://www.apache.org/licenses/LICENSE-2.0
-
-Unless required by applicable law or agreed to in writing,
-software distributed under the License is distributed on an
-"AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-KIND, either express or implied.  See the License for the
-specific language governing permissions and limitations
-under the License.
--->
-
-<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.
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/439125ae/site-releases/0.7.0-incubating/src/site/resources/.htaccess
----------------------------------------------------------------------
diff --git a/site-releases/0.7.0-incubating/src/site/resources/.htaccess b/site-releases/0.7.0-incubating/src/site/resources/.htaccess
deleted file mode 100644
index d5c7bf3..0000000
--- a/site-releases/0.7.0-incubating/src/site/resources/.htaccess
+++ /dev/null
@@ -1,20 +0,0 @@
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-
-Redirect /download.html /download.cgi

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/439125ae/site-releases/0.7.0-incubating/src/site/resources/download.cgi
----------------------------------------------------------------------
diff --git a/site-releases/0.7.0-incubating/src/site/resources/download.cgi b/site-releases/0.7.0-incubating/src/site/resources/download.cgi
deleted file mode 100644
index f9a0e30..0000000
--- a/site-releases/0.7.0-incubating/src/site/resources/download.cgi
+++ /dev/null
@@ -1,22 +0,0 @@
-#!/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/439125ae/site-releases/0.7.0-incubating/src/site/resources/images/HELIX-components.png
----------------------------------------------------------------------
diff --git a/site-releases/0.7.0-incubating/src/site/resources/images/HELIX-components.png b/site-releases/0.7.0-incubating/src/site/resources/images/HELIX-components.png
deleted file mode 100644
index c0c35ae..0000000
Binary files a/site-releases/0.7.0-incubating/src/site/resources/images/HELIX-components.png and /dev/null differ

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

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

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/439125ae/site-releases/0.7.0-incubating/src/site/resources/images/bootstrap_statemodel.gif
----------------------------------------------------------------------
diff --git a/site-releases/0.7.0-incubating/src/site/resources/images/bootstrap_statemodel.gif b/site-releases/0.7.0-incubating/src/site/resources/images/bootstrap_statemodel.gif
deleted file mode 100644
index b8f8a42..0000000
Binary files a/site-releases/0.7.0-incubating/src/site/resources/images/bootstrap_statemodel.gif and /dev/null differ

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/439125ae/site-releases/0.7.0-incubating/src/site/resources/images/helix-architecture.png
----------------------------------------------------------------------
diff --git a/site-releases/0.7.0-incubating/src/site/resources/images/helix-architecture.png b/site-releases/0.7.0-incubating/src/site/resources/images/helix-architecture.png
deleted file mode 100644
index 6f69a2d..0000000
Binary files a/site-releases/0.7.0-incubating/src/site/resources/images/helix-architecture.png and /dev/null differ

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/439125ae/site-releases/0.7.0-incubating/src/site/resources/images/helix-logo.jpg
----------------------------------------------------------------------
diff --git a/site-releases/0.7.0-incubating/src/site/resources/images/helix-logo.jpg b/site-releases/0.7.0-incubating/src/site/resources/images/helix-logo.jpg
deleted file mode 100644
index d6428f6..0000000
Binary files a/site-releases/0.7.0-incubating/src/site/resources/images/helix-logo.jpg and /dev/null differ

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/439125ae/site-releases/0.7.0-incubating/src/site/resources/images/helix-znode-layout.png
----------------------------------------------------------------------
diff --git a/site-releases/0.7.0-incubating/src/site/resources/images/helix-znode-layout.png b/site-releases/0.7.0-incubating/src/site/resources/images/helix-znode-layout.png
deleted file mode 100644
index 5bafc45..0000000
Binary files a/site-releases/0.7.0-incubating/src/site/resources/images/helix-znode-layout.png and /dev/null differ

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/439125ae/site-releases/0.7.0-incubating/src/site/resources/images/statemachine.png
----------------------------------------------------------------------
diff --git a/site-releases/0.7.0-incubating/src/site/resources/images/statemachine.png b/site-releases/0.7.0-incubating/src/site/resources/images/statemachine.png
deleted file mode 100644
index 43d27ec..0000000
Binary files a/site-releases/0.7.0-incubating/src/site/resources/images/statemachine.png and /dev/null differ

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/439125ae/site-releases/0.7.0-incubating/src/site/resources/images/system.png
----------------------------------------------------------------------
diff --git a/site-releases/0.7.0-incubating/src/site/resources/images/system.png b/site-releases/0.7.0-incubating/src/site/resources/images/system.png
deleted file mode 100644
index f8a05c8..0000000
Binary files a/site-releases/0.7.0-incubating/src/site/resources/images/system.png and /dev/null differ

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/439125ae/site-releases/0.7.0-incubating/src/site/site.xml
----------------------------------------------------------------------
diff --git a/site-releases/0.7.0-incubating/src/site/site.xml b/site-releases/0.7.0-incubating/src/site/site.xml
deleted file mode 100644
index babbe1c..0000000
--- a/site-releases/0.7.0-incubating/src/site/site.xml
+++ /dev/null
@@ -1,120 +0,0 @@
-<?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/site-releases/0.7.0-incubating-site</href>
-  </bannerLeft>
-  <bannerRight>
-    <src>http://incubator.apache.org/images/egg-logo.png</src>
-    <href>http://incubator.apache.org/</href>
-  </bannerRight>
-  <version position="none"/>
-
-  <publishDate position="right"/>
-
-  <skin>
-    <groupId>org.apache.maven.skins</groupId>
-    <artifactId>maven-fluido-skin</artifactId>
-    <version>1.3.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/site-releases/0.7.0-incubating-site/"/>
-    </breadcrumbs>
-
-    <menu name="Apache Helix">
-      <item name="Home" href="../../index.html"/>
-    </menu>
-
-    <menu name="Helix 0.7.0-incubating">
-      <item name="Introduction" href="./index.html"/>
-      <item name="Getting Helix" href="./Building.html"/>
-      <item name="Core concepts" href="./Concepts.html"/>
-      <item name="Architecture" href="./Architecture.html"/>
-      <item name="Quick Start" href="./Quickstart.html"/>
-      <item name="Tutorial" href="./Tutorial.html"/>
-      <item name="Release Notes" href="releasenotes/release-0.7.0-incubating.html"/>
-      <item name="Download" href="./download.html"/>
-    </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>
-    <fluidoSkin>
-      <topBarEnabled>true</topBarEnabled>
-      <!-- twitter link work only with sidebar disabled -->
-      <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/439125ae/site-releases/0.7.0-incubating/src/site/xdoc/download.xml.vm
----------------------------------------------------------------------
diff --git a/site-releases/0.7.0-incubating/src/site/xdoc/download.xml.vm b/site-releases/0.7.0-incubating/src/site/xdoc/download.xml.vm
deleted file mode 100644
index 14e22c5..0000000
--- a/site-releases/0.7.0-incubating/src/site/xdoc/download.xml.vm
+++ /dev/null
@@ -1,213 +0,0 @@
-<?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 Incubator 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/439125ae/site-releases/0.7.0-incubating/src/test/conf/testng.xml
----------------------------------------------------------------------
diff --git a/site-releases/0.7.0-incubating/src/test/conf/testng.xml b/site-releases/0.7.0-incubating/src/test/conf/testng.xml
deleted file mode 100644
index 58f0803..0000000
--- a/site-releases/0.7.0-incubating/src/test/conf/testng.xml
+++ /dev/null
@@ -1,27 +0,0 @@
-<?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/439125ae/site-releases/pom.xml
----------------------------------------------------------------------
diff --git a/site-releases/pom.xml b/site-releases/pom.xml
deleted file mode 100644
index bfdb1f4..0000000
--- a/site-releases/pom.xml
+++ /dev/null
@@ -1,50 +0,0 @@
-<?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>site-releases</artifactId>
-  <name>Apache Helix :: Site Releases</name>
-
-  <modules>
-    <module>0.6.1-incubating</module>
-    <module>0.6.2-incubating</module>
-    <module>0.7.0-incubating</module>
-    <module>trunk</module>
-  </modules>
-
-  <properties>
-  </properties>
-
-  <dependencies>
-  </dependencies>
-  <build>
-    <resources>
-    </resources>
-    <plugins>
-    </plugins>
-  </build>
-</project>

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/439125ae/site-releases/trunk/pom.xml
----------------------------------------------------------------------
diff --git a/site-releases/trunk/pom.xml b/site-releases/trunk/pom.xml
deleted file mode 100644
index 1ccdf0d..0000000
--- a/site-releases/trunk/pom.xml
+++ /dev/null
@@ -1,51 +0,0 @@
-<?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/maven-v4_0_0.xsd">
-  <modelVersion>4.0.0</modelVersion>
-
-  <parent>
-    <groupId>org.apache.helix</groupId>
-    <artifactId>site-releases</artifactId>
-    <version>0.7.1-incubating-SNAPSHOT</version>
-  </parent>
-
-  <artifactId>trunk-site</artifactId>
-  <packaging>bundle</packaging>
-  <name>Apache Helix :: Site :: trunk</name>
-
-  <properties>
-  </properties>
-
-  <dependencies>
-    <dependency>
-      <groupId>org.testng</groupId>
-      <artifactId>testng</artifactId>
-      <version>6.0.1</version>
-    </dependency>
-  </dependencies>
-  <build>
-    <pluginManagement>
-      <plugins>
-      </plugins>
-    </pluginManagement>
-    <plugins>
-    </plugins>
-  </build>
-</project>

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/439125ae/site-releases/trunk/src/site/apt/privacy-policy.apt
----------------------------------------------------------------------
diff --git a/site-releases/trunk/src/site/apt/privacy-policy.apt b/site-releases/trunk/src/site/apt/privacy-policy.apt
deleted file mode 100644
index ada9363..0000000
--- a/site-releases/trunk/src/site/apt/privacy-policy.apt
+++ /dev/null
@@ -1,52 +0,0 @@
- ----
- 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/439125ae/site-releases/trunk/src/site/apt/releasing.apt
----------------------------------------------------------------------
diff --git a/site-releases/trunk/src/site/apt/releasing.apt b/site-releases/trunk/src/site/apt/releasing.apt
deleted file mode 100644
index 11d0cd9..0000000
--- a/site-releases/trunk/src/site/apt/releasing.apt
+++ /dev/null
@@ -1,107 +0,0 @@
- -----
- 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 the dev list a few days before you plan to do an Helix release
-
- [[2]] Your maven setting must contains the entry to be able to deploy.
-
- ~/.m2/settings.xml
-
-+-------------
-   <server>
-     <id>apache.releases.https</id>
-     <username></username>
-     <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.
-
-   Run the release
-
-+-------------
-mvn release:prepare release:perform -B
-+-------------
-
-  GPG configuration in maven settings xml:
-
-+-------------
-<profile>
-  <id>apache-release</id>
-  <properties>
-    <gpg.passphrase>[GPG_PASSWORD]</gpg.passphrase>
-  </properties>
-</profile>
-+-------------
-
- [[4]] go to https://repository.apache.org and close your staged repository. Note the repository url (format https://repository.apache.org/content/repositories/orgapachehelix-019/org/apache/helix/helix/0.6-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
-then svn add <new directory created with new version as name>
-then svn ci 
-+-------------
-
- [[5]] Validating 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>
-+-------------
-
- [[6]] Call for a vote in the dev list and wait for 72 hrs. for the vote results. 3 binding votes are necessary for the release to be finalized. example
-  After the vote has passed, move the files from dist dev to dist release: svn mv https://dist.apache.org/repos/dist/dev/incubator/helix/version to https://dist.apache.org/repos/dist/release/incubator/helix/
-
- [[7]] Prepare release note. Add a page in src/site/apt/releasenotes/ and change value of \<currentRelease> in parent pom.
-
-
- [[8]] Send out an announcement of the release to:
-
-  * users@helix.incubator.apache.org
-
-  * dev@helix.incubator.apache.org
-
- [[9]] Celebrate !
-
-

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/439125ae/site-releases/trunk/src/site/markdown/Architecture.md
----------------------------------------------------------------------
diff --git a/site-releases/trunk/src/site/markdown/Architecture.md b/site-releases/trunk/src/site/markdown/Architecture.md
deleted file mode 100644
index 933e917..0000000
--- a/site-releases/trunk/src/site/markdown/Architecture.md
+++ /dev/null
@@ -1,252 +0,0 @@
-<!---
-Licensed to the Apache Software Foundation (ASF) under one
-or more contributor license agreements.  See the NOTICE file
-distributed with this work for additional information
-regarding copyright ownership.  The ASF licenses this file
-to you under the Apache License, Version 2.0 (the
-"License"); you may not use this file except in compliance
-with the License.  You may obtain a copy of the License at
-
-  http://www.apache.org/licenses/LICENSE-2.0
-
-Unless required by applicable law or agreed to in writing,
-software distributed under the License is distributed on an
-"AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-KIND, either express or implied.  See the License for the
-specific language governing permissions and limitations
-under the License.
--->
-
-<head>
-  <title>Architecture</title>
-</head>
-
-Architecture
-----------------------------
-Helix aims to provide the following abilities to a distributed system:
-
-* Automatic management of a cluster hosting partitioned, replicated resources.
-* Soft and hard failure detection and handling.
-* Automatic load balancing via smart placement of resources on servers(nodes) based on server capacity and resource profile (size of partition, access patterns, etc).
-* Centralized config management and self discovery. Eliminates the need to modify config on each node.
-* Fault tolerance and optimized rebalancing during cluster expansion.
-* Manages entire operational lifecycle of a node. Addition, start, stop, enable/disable without downtime.
-* Monitor cluster health and provide alerts on SLA violation.
-* Service discovery mechanism to route requests.
-
-To build such a system, we need a mechanism to co-ordinate between different nodes and other components in the system. This mechanism can be achieved with software that reacts to any change in the cluster and comes up with a set of tasks needed to bring the cluster to a stable state. The set of tasks will be assigned to one or more nodes in the cluster. Helix serves this purpose of managing the various components in the cluster.
-
-![Helix Design](images/system.png)
-
-Distributed System Components
-
-In general any distributed system cluster will have the following components and properties:
-
-* A set of nodes also referred to as instances.
-* A set of resources which can be databases, lucene indexes or tasks.
-* Each resource is also partitioned into one or more Partitions. 
-* Each partition may have one or more copies called replicas.
-* Each replica can have a state associated with it. For example Master, Slave, Leader, Standby, Online, Offline etc
-
-Roles
------
-
-![Helix Design](images/HELIX-components.png)
-
-Not all nodes in a distributed system will perform similar functionalities. For example, a few nodes might be serving requests and a few nodes might be sending requests, and some nodes might be controlling the nodes in the cluster. Thus, Helix categorizes nodes by their specific roles in the system.
-
-We have divided Helix nodes into 3 logical components based on their responsibilities:
-
-1. Participant: The nodes that actually host the distributed resources.
-2. Spectator: The nodes that simply observe the Participant state and route the request accordingly. Routers, for example, need to know the instance on which a partition is hosted and its state in order to route the request to the appropriate end point.
-3. Controller: The controller observes and controls the Participant nodes. It is responsible for coordinating all transitions in the cluster and ensuring that state constraints are satisfied and cluster stability is maintained. 
-
-These are simply logical components and can be deployed as per the system requirements. For example:
-
-1. The controller can be deployed as a separate service
-2. The controller can be deployed along with a Participant but only one Controller will be active at any given time.
-
-Both have pros and cons, which will be discussed later and one can chose the mode of deployment as per system needs.
-
-
-## Cluster state metadata store
-
-We need a distributed store to maintain the state of the cluster and a notification system to notify if there is any change in the cluster state. Helix uses Zookeeper to achieve this functionality.
-
-Zookeeper provides:
-
-* A way to represent PERSISTENT state which basically remains until its deleted.
-* A way to represent TRANSIENT/EPHEMERAL state which vanishes when the process that created the state dies.
-* Notification mechanism when there is a change in PERSISTENT and EPHEMERAL state
-
-The namespace provided by ZooKeeper is much like that of a standard file system. A name is a sequence of path elements separated by a slash (/). Every node[ZNode] in ZooKeeper\'s namespace is identified by a path.
-
-More info on Zookeeper can be found at http://zookeeper.apache.org
-
-## State machine and constraints
-
-Even though the concepts of Resources, Partitions, and Replicas are common to most distributed systems, one thing that differentiates one distributed system from another is the way each partition is assigned a state and the constraints on each state.
-
-For example:
-
-1. If a system is serving read-only data then all partition\'s replicas are equal and they can either be ONLINE or OFFLINE.
-2. If a system takes _both_ reads and writes but ensure that writes go through only one partition, the states will be MASTER, SLAVE, and OFFLINE. Writes go through the MASTER and replicate to the SLAVEs. Optionally, reads can go through SLAVES.
-
-Apart from defining state for each partition, the transition path to each state can be application specific. For example, in order to become MASTER it might be a requirement to first become a SLAVE. This ensures that if the SLAVE does not have the data as part of OFFLINE-SLAVE transition it can bootstrap data from other nodes in the system.
-
-Helix provides a way to configure an application specific state machine along with constraints on each state. Along with constraints on STATE, Helix also provides a way to specify constraints on transitions.  (More on this later.)
-
-```
-          OFFLINE  | SLAVE  |  MASTER  
-         _____________________________
-        |          |        |         |
-OFFLINE |   N/A    | SLAVE  | SLAVE   |
-        |__________|________|_________|
-        |          |        |         |
-SLAVE   |  OFFLINE |   N/A  | MASTER  |
-        |__________|________|_________|
-        |          |        |         |
-MASTER  | SLAVE    | SLAVE  |   N/A   |
-        |__________|________|_________|
-
-```
-
-![Helix Design](images/statemachine.png)
-
-## Concepts
-
-The following terminologies are used in Helix to model a state machine.
-
-* IdealState: The state in which we need the cluster to be in if all nodes are up and running. In other words, all state constraints are satisfied.
-* CurrentState: Represents the actual current state of each node in the cluster 
-* ExternalView: Represents the combined view of CurrentState of all nodes.  
-
-The goal of Helix is always to make the CurrentState of the system same as the IdealState. Some scenarios where this may not be true are:
-
-* When all nodes are down
-* When one or more nodes fail
-* New nodes are added and the partitions need to be reassigned
-
-### IdealState
-
-Helix lets the application define the IdealState on a resource basis which basically consists of:
-
-* List of partitions. Example: 64
-* Number of replicas for each partition. Example: 3
-* Node and State for each replica.
-
-Example:
-
-* Partition-1, replica-1, Master, Node-1
-* Partition-1, replica-2, Slave, Node-2
-* Partition-1, replica-3, Slave, Node-3
-* .....
-* .....
-* Partition-p, replica-3, Slave, Node-n
-
-Helix comes with various algorithms to automatically assign the partitions to nodes. The default algorithm minimizes the number of shuffles that happen when new nodes are added to the system.
-
-### CurrentState
-
-Every instance in the cluster hosts one or more partitions of a resource. Each of the partitions has a state associated with it.
-
-Example Node-1
-
-* Partition-1, Master
-* Partition-2, Slave
-* ....
-* ....
-* Partition-p, Slave
-
-### ExternalView
-
-External clients needs to know the state of each partition in the cluster and the Node hosting that partition. Helix provides one view of the system to Spectators as _ExternalView_. ExternalView is simply an aggregate of all node CurrentStates.
-
-* Partition-1, replica-1, Master, Node-1
-* Partition-1, replica-2, Slave, Node-2
-* Partition-1, replica-3, Slave, Node-3
-* .....
-* .....
-* Partition-p, replica-3, Slave, Node-n
-
-## Process Workflow
-
-Mode of operation in a cluster
-
-A node process can be one of the following:
-
-* Participant: The process registers itself in the cluster and acts on the messages received in its queue and updates the current state.  Example: a storage node in a distributed database
-* Spectator: The process is simply interested in the changes in the Externalview.
-* Controller: This process actively controls the cluster by reacting to changes in cluster state and sending messages to Participants.
-
-
-### Participant Node Process
-
-* When Node starts up, it registers itself under _LiveInstances_
-* After registering, it waits for new _Messages_ in the message queue
-* When it receives a message, it will perform the required task as indicated in the message
-* After the task is completed, depending on the task outcome it updates the CurrentState
-
-### Controller Process
-
-* Watches IdealState
-* Notified when a node goes down/comes up or node is added/removed. Watches LiveInstances and CurrentState of each node in the cluster
-* Triggers appropriate state transitions by sending message to Participants
-
-### Spectator Process
-
-* When the process starts, it asks the Helix agent to be notified of changes in ExternalView
-* Whenever it receives a notification, it reads the Externalview and performs required duties.
-
-#### Interaction between controller, participant and spectator
-
-The following picture shows how controllers, participants and spectators interact with each other.
-
-![Helix Architecture](images/helix-architecture.png)
-
-## Core algorithm
-
-* Controller gets the IdealState and the CurrentState of active storage nodes from Zookeeper
-* Compute the delta between IdealState and CurrentState for each partition across all participant nodes
-* For each partition compute tasks based on the State Machine Table. It\'s possible to configure priority on the state Transition. For example, in case of Master-Slave:
-    * Attempt mastership transfer if possible without violating constraint.
-    * Partition Addition
-    * Drop Partition 
-* Add the tasks in parallel if possible to the respective queue for each storage node (if the tasks added are mutually independent)
-* If a task is dependent on another task being completed, do not add that task
-* After any task is completed by a Participant, Controllers gets notified of the change and the State Transition algorithm is re-run until the CurrentState is same as IdealState.
-
-## Helix ZNode layout
-
-Helix organizes znodes under clusterName in multiple levels. 
-
-The top level (under the cluster name) ZNodes are all Helix-defined and in upper case:
-
-* PROPERTYSTORE: application property store
-* STATEMODELDEFES: state model definitions
-* INSTANCES: instance runtime information including current state and messages
-* CONFIGS: configurations
-* IDEALSTATES: ideal states
-* EXTERNALVIEW: external views
-* LIVEINSTANCES: live instances
-* CONTROLLER: cluster controller runtime information
-
-Under INSTANCES, there are runtime ZNodes for each instance. An instance organizes ZNodes as follows:
-
-* CURRENTSTATES
-    * sessionId
-    * resourceName
-* ERRORS
-* STATUSUPDATES
-* MESSAGES
-* HEALTHREPORT
-
-Under CONFIGS, there are different scopes of configurations:
-
-* RESOURCE: contains resource scope configurations
-* CLUSTER: contains cluster scope configurations
-* PARTICIPANT: contains participant scope configurations
-
-The following image shows an example of Helix znodes layout for a cluster named "test-cluster":
-
-![Helix znode layout](images/helix-znode-layout.png)

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/439125ae/site-releases/trunk/src/site/markdown/Building.md
----------------------------------------------------------------------
diff --git a/site-releases/trunk/src/site/markdown/Building.md b/site-releases/trunk/src/site/markdown/Building.md
deleted file mode 100644
index 2d8a51b..0000000
--- a/site-releases/trunk/src/site/markdown/Building.md
+++ /dev/null
@@ -1,29 +0,0 @@
-<!---
-Licensed to the Apache Software Foundation (ASF) under one
-or more contributor license agreements.  See the NOTICE file
-distributed with this work for additional information
-regarding copyright ownership.  The ASF licenses this file
-to you under the Apache License, Version 2.0 (the
-"License"); you may not use this file except in compliance
-with the License.  You may obtain a copy of the License at
-
-  http://www.apache.org/licenses/LICENSE-2.0
-
-Unless required by applicable law or agreed to in writing,
-software distributed under the License is distributed on an
-"AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-KIND, either express or implied.  See the License for the
-specific language governing permissions and limitations
-under the License.
--->
-
-Build Instructions
-------------------
-
-Requirements: JDK 1.6+, Maven 2.0.8+
-
-```
-git clone https://git-wip-us.apache.org/repos/asf/incubator-helix.git
-cd incubator-helix
-mvn install package -DskipTests
-```

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/439125ae/site-releases/trunk/src/site/markdown/Concepts.md
----------------------------------------------------------------------
diff --git a/site-releases/trunk/src/site/markdown/Concepts.md b/site-releases/trunk/src/site/markdown/Concepts.md
deleted file mode 100644
index fa5d0ba..0000000
--- a/site-releases/trunk/src/site/markdown/Concepts.md
+++ /dev/null
@@ -1,275 +0,0 @@
-<!---
-Licensed to the Apache Software Foundation (ASF) under one
-or more contributor license agreements.  See the NOTICE file
-distributed with this work for additional information
-regarding copyright ownership.  The ASF licenses this file
-to you under the Apache License, Version 2.0 (the
-"License"); you may not use this file except in compliance
-with the License.  You may obtain a copy of the License at
-
-  http://www.apache.org/licenses/LICENSE-2.0
-
-Unless required by applicable law or agreed to in writing,
-software distributed under the License is distributed on an
-"AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-KIND, either express or implied.  See the License for the
-specific language governing permissions and limitations
-under the License.
--->
-
-<head>
-  <title>Concepts</title>
-</head>
-
-Concepts
-----------------------------
-
-Helix is based on the idea that a given task has the following attributes associated with it:
-
-* _Location of the task_. For example it runs on Node N1
-* _State_. For example, it is running, stopped etc.
-
-In Helix terminology, a task is referred to as a _resource_.
-
-### IdealState
-
-IdealState simply allows one to map tasks to location and state. A standard way of expressing this in Helix:
-
-```
-  "TASK_NAME" : {
-    "LOCATION" : "STATE"
-  }
-
-```
-Consider a simple case where you want to launch a task \'myTask\' on node \'N1\'. The IdealState for this can be expressed as follows:
-
-```
-{
-  "id" : "MyTask",
-  "mapFields" : {
-    "myTask" : {
-      "N1" : "ONLINE",
-    }
-  }
-}
-```
-### Partition
-
-If this task get too big to fit on one box, you might want to divide it into subtasks. Each subtask is referred to as a _partition_ in Helix. Let\'s say you want to divide the task into 3 subtasks/partitions, the IdealState can be changed as shown below. 
-
-\'myTask_0\', \'myTask_1\', \'myTask_2\' are logical names representing the partitions of myTask. Each tasks runs on N1, N2 and N3 respectively.
-
-```
-{
-  "id" : "myTask",
-  "simpleFields" : {
-    "NUM_PARTITIONS" : "3",
-  }
- "mapFields" : {
-    "myTask_0" : {
-      "N1" : "ONLINE",
-    },
-    "myTask_1" : {
-      "N2" : "ONLINE",
-    },
-    "myTask_2" : {
-      "N3" : "ONLINE",
-    }
-  }
-}
-```
-
-### Replica
-
-Partitioning allows one to split the data/task into multiple subparts. But let\'s say the request rate for each partition increases. The common solution is to have multiple copies for each partition. Helix refers to the copy of a partition as a _replica_.  Adding a replica also increases the availability of the system during failures. One can see this methodology employed often in search systems. The index is divided into shards, and each shard has multiple copies.
-
-Let\'s say you want to add one additional replica for each task. The IdealState can simply be changed as shown below. 
-
-For increasing the availability of the system, it\'s better to place the replica of a given partition on different nodes.
-
-```
-{
-  "id" : "myIndex",
-  "simpleFields" : {
-    "NUM_PARTITIONS" : "3",
-    "REPLICAS" : "2",
-  },
- "mapFields" : {
-    "myIndex_0" : {
-      "N1" : "ONLINE",
-      "N2" : "ONLINE"
-    },
-    "myIndex_1" : {
-      "N2" : "ONLINE",
-      "N3" : "ONLINE"
-    },
-    "myIndex_2" : {
-      "N3" : "ONLINE",
-      "N1" : "ONLINE"
-    }
-  }
-}
-```
-
-### State 
-
-Now let\'s take a slightly more complicated scenario where a task represents a database.  Unlike an index which is in general read-only, a database supports both reads and writes. Keeping the data consistent among the replicas is crucial in distributed data stores. One commonly applied technique is to assign one replica as the MASTER and remaining replicas as SLAVEs. All writes go to the MASTER and are then replicated to the SLAVE replicas.
-
-Helix allows one to assign different states to each replica. Let\'s say you have two MySQL instances N1 and N2, where one will serve as MASTER and another as SLAVE. The IdealState can be changed to:
-
-```
-{
-  "id" : "myDB",
-  "simpleFields" : {
-    "NUM_PARTITIONS" : "1",
-    "REPLICAS" : "2",
-  },
-  "mapFields" : {
-    "myDB" : {
-      "N1" : "MASTER",
-      "N2" : "SLAVE",
-    }
-  }
-}
-
-```
-
-
-### State Machine and Transitions
-
-IdealState allows one to exactly specify the desired state of the cluster. Given an IdealState, Helix takes up the responsibility of ensuring that the cluster reaches the IdealState.  The Helix _controller_ reads the IdealState and then commands each Participant to take appropriate actions to move from one state to another until it matches the IdealState.  These actions are referred to as _transitions_ in Helix.
-
-The next logical question is:  how does the _controller_ compute the transitions required to get to IdealState?  This is where the finite state machine concept comes in. Helix allows applications to plug in a finite state machine.  A state machine consists of the following:
-
-* State: Describes the role of a replica
-* Transition: An action that allows a replica to move from one state to another, thus changing its role.
-
-Here is an example of MasterSlave state machine:
-
-```
-          OFFLINE  | SLAVE  |  MASTER  
-         _____________________________
-        |          |        |         |
-OFFLINE |   N/A    | SLAVE  | SLAVE   |
-        |__________|________|_________|
-        |          |        |         |
-SLAVE   |  OFFLINE |   N/A  | MASTER  |
-        |__________|________|_________|
-        |          |        |         |
-MASTER  | SLAVE    | SLAVE  |   N/A   |
-        |__________|________|_________|
-
-```
-
-Helix allows each resource to be associated with one state machine. This means you can have one resource as an index and another as a database in the same cluster. One can associate each resource with a state machine as follows:
-
-```
-{
-  "id" : "myDB",
-  "simpleFields" : {
-    "NUM_PARTITIONS" : "1",
-    "REPLICAS" : "2",
-    "STATE_MODEL_DEF_REF" : "MasterSlave",
-  },
-  "mapFields" : {
-    "myDB" : {
-      "N1" : "MASTER",
-      "N2" : "SLAVE",
-    }
-  }
-}
-
-```
-
-### Current State
-
-CurrentState of a resource simply represents its actual state at a Participant. In the below example:
-
-* INSTANCE_NAME: Unique name representing the process
-* SESSION_ID: ID that is automatically assigned every time a process joins the cluster
-
-```
-{
-  "id":"MyResource"
-  ,"simpleFields":{
-    ,"SESSION_ID":"13d0e34675e0002"
-    ,"INSTANCE_NAME":"node1"
-    ,"STATE_MODEL_DEF":"MasterSlave"
-  }
-  ,"mapFields":{
-    "MyResource_0":{
-      "CURRENT_STATE":"SLAVE"
-    }
-    ,"MyResource_1":{
-      "CURRENT_STATE":"MASTER"
-    }
-    ,"MyResource_2":{
-      "CURRENT_STATE":"MASTER"
-    }
-  }
-}
-```
-Each node in the cluster has its own CurrentState.
-
-### External View
-
-In order to communicate with the Participants, external clients need to know the current state of each of the Participants. The external clients are referred to as Spectators. In order to make the life of Spectator simple, Helix provides an ExternalView that is an aggregated view of the current state across all nodes. The ExternalView has a similar format as IdealState.
-
-```
-{
-  "id":"MyResource",
-  "mapFields":{
-    "MyResource_0":{
-      "N1":"SLAVE",
-      "N2":"MASTER",
-      "N3":"OFFLINE"
-    },
-    "MyResource_1":{
-      "N1":"MASTER",
-      "N2":"SLAVE",
-      "N3":"ERROR"
-    },
-    "MyResource_2":{
-      "N1":"MASTER",
-      "N2":"SLAVE",
-      "N3":"SLAVE"
-    }
-  }
-}
-```
-
-### Rebalancer
-
-The core component of Helix is the Controller which runs the Rebalancer algorithm on every cluster event. Cluster events can be one of the following:
-
-* Nodes start/stop and soft/hard failures
-* New nodes are added/removed
-* Ideal state changes
-
-There are few more examples such as configuration changes, etc.  The key takeaway: there are many ways to trigger the rebalancer.
-
-When a rebalancer is run it simply does the following:
-
-* Compares the IdealState and current state
-* Computes the transitions required to reach the IdealState
-* Issues the transitions to each Participant
-
-The above steps happen for every change in the system. Once the current state matches the IdealState, the system is considered stable which implies \'IdealState = CurrentState = ExternalView\'
-
-### Dynamic IdealState
-
-One of the things that makes Helix powerful is that IdealState can be changed dynamically. This means one can listen to cluster events like node failures and dynamically change the ideal state. Helix will then take care of triggering the respective transitions in the system.
-
-Helix comes with a few algorithms to automatically compute the IdealState based on the constraints. For example, if you have a resource of 3 partitions and 2 replicas, Helix can automatically compute the IdealState based on the nodes that are currently active. See the [tutorial](./tutorial_rebalance.html) to find out more about various execution modes of Helix like FULL_AUTO, SEMI_AUTO and CUSTOMIZED. 
-
-
-
-
-
-
-
-
-
-
-
-