You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@helix.apache.org by ol...@apache.org on 2012/10/25 23:53:39 UTC

[1/11] git commit: [HELIX-3] Fix license headers in sources *.java in helix-core

Updated Branches:
  refs/heads/master de588e282 -> 687e839d3


[HELIX-3] Fix license headers in sources
*.java in helix-core


Project: http://git-wip-us.apache.org/repos/asf/incubator-helix/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-helix/commit/c54c6163
Tree: http://git-wip-us.apache.org/repos/asf/incubator-helix/tree/c54c6163
Diff: http://git-wip-us.apache.org/repos/asf/incubator-helix/diff/c54c6163

Branch: refs/heads/master
Commit: c54c616333fa4a6d28b2fdf4d256d3e9d928b076
Parents: de588e2
Author: olivier lamy <ol...@apache.org>
Authored: Thu Oct 25 23:40:44 2012 +0200
Committer: olivier lamy <ol...@apache.org>
Committed: Thu Oct 25 23:53:15 2012 +0200

----------------------------------------------------------------------
 .../apache/helix/alerts/AccumulateAggregator.java  |    2 -
 .../java/org/apache/helix/alerts/package-info.java |   18 +++++++
 .../org/apache/helix/controller/package-info.java  |   18 +++++++
 .../helix/controller/pipeline/package-info.java    |   18 +++++++
 .../helix/controller/restlet/package-info.java     |   18 +++++++
 .../helix/controller/stages/package-info.java      |   18 +++++++
 .../apache/helix/examples/BootstrapHandler.java    |   30 ++++++-----
 .../apache/helix/examples/DummyParticipant.java    |   19 +++++++
 .../org/apache/helix/examples/ExampleHelper.java   |   19 +++++++
 .../org/apache/helix/examples/ExampleProcess.java  |   30 ++++++-----
 .../apache/helix/examples/IdealStateExample.java   |   22 +++++++-
 .../examples/LeaderStandbyStateModelFactory.java   |   30 ++++++-----
 .../examples/MasterSlaveStateModelFactory.java     |   30 ++++++-----
 .../examples/OnlineOfflineStateModelFactory.java   |   30 ++++++-----
 .../org/apache/helix/examples/package-info.java    |   18 +++++++
 .../healthcheck/AccumulateAggregationType.java     |   30 ++++++-----
 .../apache/helix/healthcheck/AggregationType.java  |   30 ++++++-----
 .../helix/healthcheck/AggregationTypeFactory.java  |   30 ++++++-----
 .../helix/healthcheck/DecayAggregationType.java    |   32 ++++++------
 .../healthcheck/DefaultHealthReportProvider.java   |   30 ++++++-----
 .../helix/healthcheck/DefaultPerfCounters.java     |   30 ++++++-----
 .../helix/healthcheck/HealthReportProvider.java    |   30 ++++++-----
 .../healthcheck/HealthStatsAggregationTask.java    |   30 ++++++-----
 .../ParticipantHealthReportCollector.java          |   30 ++++++-----
 .../ParticipantHealthReportCollectorImpl.java      |   30 ++++++-----
 .../PerformanceHealthReportProvider.java           |   30 ++++++-----
 .../java/org/apache/helix/healthcheck/Stat.java    |   39 +++++++--------
 .../healthcheck/StatHealthReportProvider.java      |   36 +++++++------
 .../helix/healthcheck/WindowAggregationType.java   |   32 ++++++------
 .../org/apache/helix/healthcheck/package-info.java |   18 +++++++
 .../helix/josql/ClusterJosqlQueryProcessor.java    |   30 ++++++-----
 .../helix/josql/ZNRecordJosqlFunctionHandler.java  |   30 ++++++-----
 .../java/org/apache/helix/josql/ZNRecordRow.java   |   30 ++++++-----
 .../java/org/apache/helix/josql/package-info.java  |   18 +++++++
 .../manager/file/DynamicFileHelixManager.java      |   31 +++++++-----
 .../helix/manager/file/FileCallbackHandler.java    |   31 +++++++-----
 .../helix/manager/file/FileDataAccessor.java       |   31 +++++++-----
 .../apache/helix/manager/file/FileHelixAdmin.java  |   31 +++++++-----
 .../helix/manager/file/FileHelixDataAccessor.java  |   20 ++++++++
 .../helix/manager/file/StaticFileHelixManager.java |   31 +++++++-----
 .../apache/helix/manager/file/package-info.java    |   18 +++++++
 .../apache/helix/manager/zk/BasicZkSerializer.java |   31 +++++++-----
 .../helix/manager/zk/ByteArraySerializer.java      |   20 ++++++++
 .../java/org/apache/helix/manager/zk/Cache.java    |   19 +++++++
 .../apache/helix/manager/zk/CallbackHandler.java   |   30 ++++++-----
 .../helix/manager/zk/ChainedPathZkSerializer.java  |   19 +++++++
 .../zk/DefaultControllerMessageHandlerFactory.java |   31 +++++++-----
 ...faultParticipantErrorMessageHandlerFactory.java |   18 +++++++
 .../zk/DefaultSchedulerMessageHandlerFactory.java  |   30 ++++++-----
 .../apache/helix/manager/zk/HelixGroupCommit.java  |   18 +++++++
 .../helix/manager/zk/PathBasedZkSerializer.java    |   19 +++++++
 .../apache/helix/manager/zk/WriteThroughCache.java |   20 ++++++++
 .../apache/helix/manager/zk/ZKDataAccessor.java    |   30 ++++++-----
 .../helix/manager/zk/ZKExceptionHandler.java       |   30 ++++++-----
 .../org/apache/helix/manager/zk/ZKHelixAdmin.java  |   30 ++++++-----
 .../helix/manager/zk/ZKHelixDataAccessor.java      |   18 +++++++
 .../apache/helix/manager/zk/ZKHelixManager.java    |   30 ++++++-----
 .../java/org/apache/helix/manager/zk/ZKUtil.java   |   30 ++++++-----
 .../helix/manager/zk/ZNRecordSerializer.java       |   30 ++++++-----
 .../manager/zk/ZNRecordStreamingSerializer.java    |   19 +++++++
 .../apache/helix/manager/zk/ZkAsyncCallbacks.java  |   19 +++++++
 .../helix/manager/zk/ZkBaseDataAccessor.java       |   19 +++++++
 .../helix/manager/zk/ZkCacheBaseDataAccessor.java  |   19 +++++++
 .../helix/manager/zk/ZkCacheEventThread.java       |   19 +++++++
 .../apache/helix/manager/zk/ZkCallbackCache.java   |   19 +++++++
 .../java/org/apache/helix/manager/zk/ZkClient.java |   30 ++++++-----
 .../helix/manager/zk/ZkStateChangeListener.java    |   30 ++++++-----
 .../org/apache/helix/manager/zk/package-info.java  |   18 +++++++
 .../org/apache/helix/messaging/AsyncCallback.java  |   30 ++++++-----
 .../apache/helix/messaging/CriteriaEvaluator.java  |   30 ++++++-----
 .../helix/messaging/DefaultMessagingService.java   |   30 ++++++-----
 .../messaging/handling/AsyncCallbackService.java   |   30 ++++++-----
 .../messaging/handling/GroupMessageHandler.java    |   18 +++++++
 .../handling/HelixStateTransitionHandler.java      |   30 ++++++-----
 .../apache/helix/messaging/handling/HelixTask.java |   30 ++++++-----
 .../messaging/handling/HelixTaskExecutor.java      |   30 ++++++-----
 .../helix/messaging/handling/HelixTaskResult.java  |   30 ++++++-----
 .../helix/messaging/handling/MessageHandler.java   |   31 +++++++-----
 .../messaging/handling/MessageHandlerFactory.java  |   36 ++++++++------
 .../helix/messaging/handling/package-info.java     |   18 +++++++
 .../org/apache/helix/messaging/package-info.java   |   18 +++++++
 .../java/org/apache/helix/model/AlertHistory.java  |   18 +++++++
 .../java/org/apache/helix/model/AlertStatus.java   |   30 ++++++-----
 .../main/java/org/apache/helix/model/Alerts.java   |   30 ++++++-----
 .../org/apache/helix/model/ClusterConstraints.java |   30 ++++++-----
 .../java/org/apache/helix/model/CurrentState.java  |   30 ++++++-----
 .../main/java/org/apache/helix/model/Error.java    |   19 +++++++
 .../java/org/apache/helix/model/ExternalView.java  |   30 ++++++-----
 .../java/org/apache/helix/model/HealthStat.java    |   30 ++++++-----
 .../java/org/apache/helix/model/IdealState.java    |   30 ++++++-----
 .../org/apache/helix/model/InstanceConfig.java     |   30 ++++++-----
 .../java/org/apache/helix/model/LeaderHistory.java |   30 ++++++-----
 .../java/org/apache/helix/model/LiveInstance.java  |   33 ++++++------
 .../main/java/org/apache/helix/model/Message.java  |   30 ++++++-----
 .../java/org/apache/helix/model/Partition.java     |   30 ++++++-----
 .../java/org/apache/helix/model/PauseSignal.java   |   30 ++++++-----
 .../org/apache/helix/model/PersistentStats.java    |   30 ++++++-----
 .../main/java/org/apache/helix/model/Resource.java |   30 ++++++-----
 .../org/apache/helix/model/ResourceAssignment.java |   30 ++++++-----
 .../apache/helix/model/StateModelDefinition.java   |   30 ++++++-----
 .../java/org/apache/helix/model/StatusUpdate.java  |   30 ++++++-----
 .../java/org/apache/helix/model/package-info.java  |   18 +++++++
 .../helix/monitoring/ParticipantMonitor.java       |   30 ++++++-----
 .../helix/monitoring/SensorNameProvider.java       |   19 +++++++
 .../org/apache/helix/monitoring/StatCollector.java |   30 ++++++-----
 .../helix/monitoring/StateTransitionContext.java   |   30 ++++++-----
 .../helix/monitoring/StateTransitionDataPoint.java |   30 ++++++-----
 .../helix/monitoring/ZKPathDataDumpTask.java       |   30 ++++++-----
 .../helix/monitoring/mbeans/ClusterAlertItem.java  |   30 ++++++-----
 .../monitoring/mbeans/ClusterAlertItemMBean.java   |   30 ++++++-----
 .../mbeans/ClusterAlertMBeanCollection.java        |   30 ++++++-----
 .../monitoring/mbeans/ClusterMBeanObserver.java    |   30 ++++++-----
 .../monitoring/mbeans/ClusterStatusMonitor.java    |   30 ++++++-----
 .../mbeans/ClusterStatusMonitorMBean.java          |   30 ++++++-----
 .../mbeans/HelixStageLatencyMonitor.java           |   30 ++++++-----
 .../mbeans/HelixStageLatencyMonitorMBean.java      |   30 ++++++-----
 .../monitoring/mbeans/MessageQueueMonitor.java     |   19 +++++++
 .../mbeans/MessageQueueMonitorMBean.java           |   19 +++++++
 .../helix/monitoring/mbeans/ResourceMonitor.java   |   30 ++++++-----
 .../monitoring/mbeans/ResourceMonitorMBean.java    |   30 ++++++-----
 .../mbeans/StateTransitionStatMonitor.java         |   30 ++++++-----
 .../mbeans/StateTransitionStatMonitorMBean.java    |   30 ++++++-----
 .../helix/monitoring/mbeans/package-info.java      |   18 +++++++
 .../org/apache/helix/monitoring/package-info.java  |   18 +++++++
 .../main/java/org/apache/helix/package-info.java   |   18 +++++++
 .../participant/CustomCodeCallbackHandler.java     |   30 ++++++-----
 .../helix/participant/CustomCodeInvoker.java       |   30 ++++++-----
 .../participant/DistClusterControllerElection.java |   30 ++++++-----
 .../DistClusterControllerStateModel.java           |   30 ++++++-----
 .../DistClusterControllerStateModelFactory.java    |   30 ++++++-----
 .../participant/GenericLeaderStandbyModel.java     |   30 ++++++-----
 .../GenericLeaderStandbyStateModelFactory.java     |   30 ++++++-----
 .../helix/participant/HelixCustomCodeRunner.java   |   30 ++++++-----
 .../helix/participant/HelixStateMachineEngine.java |   30 ++++++-----
 .../helix/participant/StateMachineEngine.java      |   30 ++++++-----
 .../org/apache/helix/participant/package-info.java |   18 +++++++
 .../helix/participant/statemachine/StateModel.java |   30 ++++++-----
 .../statemachine/StateModelFactory.java            |   30 ++++++-----
 .../participant/statemachine/StateModelInfo.java   |   30 ++++++-----
 .../participant/statemachine/StateModelParser.java |   30 ++++++-----
 .../statemachine/StateTransitionError.java         |   30 ++++++-----
 .../helix/participant/statemachine/Transition.java |   30 ++++++-----
 .../participant/statemachine/package-info.java     |   18 +++++++
 .../helix/spectator/RoutingTableProvider.java      |   30 ++++++-----
 .../org/apache/helix/spectator/package-info.java   |   18 +++++++
 .../apache/helix/store/HelixPropertyListener.java  |   19 +++++++
 .../org/apache/helix/store/HelixPropertyStore.java |   19 +++++++
 .../apache/helix/store/PropertyChangeListener.java |   30 ++++++-----
 .../apache/helix/store/PropertyJsonComparator.java |   30 ++++++-----
 .../apache/helix/store/PropertyJsonSerializer.java |   30 ++++++-----
 .../org/apache/helix/store/PropertySerializer.java |   30 ++++++-----
 .../java/org/apache/helix/store/PropertyStat.java  |   30 ++++++-----
 .../java/org/apache/helix/store/PropertyStore.java |   30 ++++++-----
 .../apache/helix/store/PropertyStoreException.java |   30 ++++++-----
 .../apache/helix/store/PropertyStoreFactory.java   |   30 ++++++-----
 .../apache/helix/store/ZNRecordJsonSerializer.java |   30 ++++++-----
 .../helix/store/file/FileHelixPropertyStore.java   |   19 +++++++
 .../apache/helix/store/file/FilePropertyStore.java |   30 ++++++-----
 .../org/apache/helix/store/file/package-info.java  |   18 +++++++
 .../java/org/apache/helix/store/package-info.java  |   18 +++++++
 .../org/apache/helix/store/zk/PropertyItem.java    |   30 ++++++-----
 .../org/apache/helix/store/zk/ZKPropertyStore.java |   30 ++++++-----
 .../main/java/org/apache/helix/store/zk/ZNode.java |   19 +++++++
 .../apache/helix/store/zk/ZkCallbackHandler.java   |   30 ++++++-----
 .../helix/store/zk/ZkHelixPropertyStore.java       |   19 +++++++
 .../java/org/apache/helix/store/zk/ZkListener.java |   19 +++++++
 .../org/apache/helix/store/zk/package-info.java    |   18 +++++++
 .../org/apache/helix/tools/CLMLogFileAppender.java |   30 ++++++-----
 .../java/org/apache/helix/tools/ClusterSetup.java  |   30 ++++++-----
 .../apache/helix/tools/ClusterStateVerifier.java   |   30 ++++++-----
 .../apache/helix/tools/ClusterViewSerializer.java  |   30 ++++++-----
 .../tools/IdealCalculatorByConsistentHashing.java  |   30 ++++++-----
 .../helix/tools/IdealStateCalculatorByRush.java    |   30 ++++++-----
 .../tools/IdealStateCalculatorByShuffling.java     |   30 ++++++-----
 .../IdealStateCalculatorForEspressoRelay.java      |   19 +++++++
 .../tools/IdealStateCalculatorForStorageNode.java  |   30 ++++++-----
 .../java/org/apache/helix/tools/JmxDumper.java     |   19 +++++++
 .../java/org/apache/helix/tools/LocalZKServer.java |   30 ++++++-----
 .../java/org/apache/helix/tools/MessagePoster.java |   30 ++++++-----
 .../org/apache/helix/tools/PropertiesReader.java   |   30 ++++++-----
 .../java/org/apache/helix/tools/RUSHrHash.java     |   30 ++++++-----
 .../helix/tools/StateModelConfigGenerator.java     |   30 ++++++-----
 .../java/org/apache/helix/tools/TestCommand.java   |   30 ++++++-----
 .../java/org/apache/helix/tools/TestExecutor.java  |   30 ++++++-----
 .../java/org/apache/helix/tools/TestTrigger.java   |   30 ++++++-----
 .../org/apache/helix/tools/YAISCalculator.java     |   30 ++++++-----
 .../main/java/org/apache/helix/tools/ZKDumper.java |   30 ++++++-----
 .../org/apache/helix/tools/ZKLogFormatter.java     |   30 ++++++-----
 .../java/org/apache/helix/tools/ZkLogAnalyzer.java |   19 +++++++
 .../org/apache/helix/tools/ZkLogCSVFormatter.java  |   30 ++++++-----
 .../java/org/apache/helix/tools/ZnodeOpArg.java    |   30 ++++++-----
 .../java/org/apache/helix/tools/ZnodeValue.java    |   30 ++++++-----
 .../java/org/apache/helix/tools/package-info.java  |   18 +++++++
 .../main/java/org/apache/helix/util/HelixUtil.java |   30 ++++++-----
 .../org/apache/helix/util/StatusUpdateUtil.java    |   30 ++++++-----
 .../java/org/apache/helix/util/StringTemplate.java |   30 ++++++-----
 .../java/org/apache/helix/util/ZKClientPool.java   |   30 ++++++-----
 .../java/org/apache/helix/util/ZNRecordUtil.java   |   30 ++++++-----
 .../java/org/apache/helix/util/package-info.java   |   18 +++++++
 .../src/test/java/org/apache/helix/AppTest.java    |   30 ++++++-----
 .../java/org/apache/helix/DummyProcessThread.java  |   31 ++++++-----
 .../java/org/apache/helix/ExternalCommand.java     |   19 +++++++
 .../src/test/java/org/apache/helix/Mocks.java      |   30 ++++++-----
 .../java/org/apache/helix/ScriptTestHelper.java    |   19 +++++++
 .../apache/helix/TestClusterviewSerializer.java    |   30 ++++++-----
 .../java/org/apache/helix/TestConfigAccessor.java  |   30 ++++++-----
 .../TestEspressoStorageClusterIdealState.java      |   30 ++++++-----
 .../java/org/apache/helix/TestGetProperty.java     |   30 ++++++-----
 .../java/org/apache/helix/TestGroupCommit.java     |   19 +++++++
 .../org/apache/helix/TestHelixTaskExecutor.java    |   34 +++++++------
 .../org/apache/helix/TestHelixTaskHandler.java     |   30 ++++++-----
 .../src/test/java/org/apache/helix/TestHelper.java |   30 ++++++-----
 .../apache/helix/TestHierarchicalDataStore.java    |   30 ++++++-----
 .../TestParticipantHealthReportCollectorImpl.java  |   36 +++++++-------
 .../java/org/apache/helix/TestPerfCounters.java    |   30 ++++++-----
 .../helix/TestPerformanceHealthReportProvider.java |   30 ++++++-----
 .../org/apache/helix/TestPropertyPathConfig.java   |   34 ++++++------
 .../helix/TestRelayIdealStateCalculator.java       |   19 +++++++
 .../java/org/apache/helix/TestRoutingTable.java    |   30 ++++++-----
 .../src/test/java/org/apache/helix/TestSample.java |   30 ++++++-----
 .../org/apache/helix/TestShuffledIdealState.java   |   30 ++++++-----
 .../test/java/org/apache/helix/TestZKCallback.java |   30 ++++++-----
 .../apache/helix/TestZKRoutingInfoProvider.java    |   30 ++++++-----
 .../test/java/org/apache/helix/TestZNRecord.java   |   30 ++++++-----
 .../org/apache/helix/TestZNRecordBucketizer.java   |   19 +++++++
 .../java/org/apache/helix/TestZkClientWrapper.java |   30 ++++++-----
 .../org/apache/helix/TestZkConnectionCount.java    |   30 ++++++-----
 .../java/org/apache/helix/TestZnodeModify.java     |   30 ++++++-----
 .../test/java/org/apache/helix/ZkTestHelper.java   |   19 +++++++
 .../test/java/org/apache/helix/ZkUnitTestBase.java |   30 ++++++-----
 .../org/apache/helix/alerts/TestAddAlerts.java     |   30 ++++++-----
 .../helix/alerts/TestAddPersistentStats.java       |   30 ++++++-----
 .../apache/helix/alerts/TestAlertValidation.java   |   30 ++++++-----
 .../helix/alerts/TestArrivingParticipantStats.java |   30 ++++++-----
 .../helix/alerts/TestBaseStatsValidation.java      |   30 ++++++-----
 .../apache/helix/alerts/TestEvaluateAlerts.java    |   30 ++++++-----
 .../org/apache/helix/alerts/TestOperators.java     |   30 ++++++-----
 .../org/apache/helix/alerts/TestStatsMatch.java    |   30 ++++++-----
 .../helix/controller/stages/BaseStageTest.java     |   30 ++++++-----
 .../controller/stages/DummyClusterManager.java     |   30 ++++++-----
 .../stages/TestBestPossibleStateCalcStage.java     |   30 ++++++-----
 .../helix/controller/stages/TestClusterEvent.java  |   33 ++++++------
 .../stages/TestCompatibilityCheckStage.java        |   30 ++++++-----
 .../stages/TestCurrentStateComputationStage.java   |   30 ++++++-----
 .../stages/TestMessageThrottleStage.java           |   30 ++++++-----
 .../controller/stages/TestMsgSelectionStage.java   |   19 +++++++
 .../controller/stages/TestParseInfoFromAlert.java  |   19 +++++++
 .../controller/stages/TestRebalancePipeline.java   |   30 ++++++-----
 .../stages/TestResourceComputationStage.java       |   30 ++++++-----
 .../apache/helix/healthcheck/TestAddDropAlert.java |   30 ++++++-----
 .../healthcheck/TestAlertActionTriggering.java     |   19 +++++++
 .../helix/healthcheck/TestAlertFireHistory.java    |   30 ++++++-----
 .../apache/helix/healthcheck/TestDummyAlerts.java  |   30 ++++++-----
 .../apache/helix/healthcheck/TestExpandAlert.java  |   30 ++++++-----
 .../apache/helix/healthcheck/TestSimpleAlert.java  |   30 ++++++-----
 .../helix/healthcheck/TestSimpleWildcardAlert.java |   30 ++++++-----
 .../helix/healthcheck/TestStalenessAlert.java      |   30 ++++++-----
 .../helix/healthcheck/TestWildcardAlert.java       |   30 ++++++-----
 .../apache/helix/integration/FileCMTestBase.java   |   30 ++++++-----
 .../apache/helix/integration/IntegrationTest.java  |   30 ++++++-----
 .../apache/helix/integration/TestAddClusterV2.java |   30 ++++++-----
 .../TestAddNodeAfterControllerStart.java           |   30 ++++++-----
 .../TestAddStateModelFactoryAfterConnect.java      |   19 +++++++
 .../helix/integration/TestAutoIsWithEmptyMap.java  |   19 +++++++
 .../helix/integration/TestAutoRebalance.java       |   19 +++++++
 .../helix/integration/TestBasicSpectator.java      |   19 +++++++
 .../helix/integration/TestBucketizedResource.java  |   19 +++++++
 .../integration/TestCMWithFailParticipant.java     |   30 ++++++-----
 .../integration/TestCarryOverBadCurState.java      |   19 +++++++
 .../helix/integration/TestClusterStartsup.java     |   30 ++++++-----
 .../helix/integration/TestCustomIdealState.java    |   30 ++++++-----
 .../org/apache/helix/integration/TestDisable.java  |   19 +++++++
 .../apache/helix/integration/TestDisableNode.java  |   30 ++++++-----
 .../helix/integration/TestDisablePartition.java    |   30 ++++++-----
 .../helix/integration/TestDistributedCMMain.java   |   19 +++++++
 .../TestDistributedClusterController.java          |   19 +++++++
 .../org/apache/helix/integration/TestDriver.java   |   30 ++++++-----
 .../org/apache/helix/integration/TestDrop.java     |   19 +++++++
 .../apache/helix/integration/TestDropResource.java |   30 ++++++-----
 .../integration/TestDynamicFileClusterManager.java |   30 ++++++-----
 .../TestEnablePartitionDuringDisable.java          |   19 +++++++
 .../helix/integration/TestErrorPartition.java      |   30 ++++++-----
 .../helix/integration/TestExpandCluster.java       |   19 +++++++
 .../apache/helix/integration/TestExternalCmd.java  |   19 +++++++
 .../helix/integration/TestExternalViewUpdates.java |   19 +++++++
 .../helix/integration/TestFailOverPerf1kp.java     |   19 +++++++
 .../integration/TestFileBasedHelixManager.java     |   30 ++++++-----
 .../apache/helix/integration/TestGroupMessage.java |   19 +++++++
 .../integration/TestHelixCustomCodeRunner.java     |   30 ++++++-----
 .../integration/TestHelixUsingDifferentParams.java |   30 ++++++-----
 .../TestMessagePartitionStateMismatch.java         |   19 +++++++
 .../helix/integration/TestMessageThrottle.java     |   19 +++++++
 .../helix/integration/TestMessagingService.java    |   30 ++++++-----
 .../helix/integration/TestNonOfflineInitState.java |   19 +++++++
 .../apache/helix/integration/TestNullReplica.java  |   19 +++++++
 .../integration/TestParticipantErrorMessage.java   |   19 +++++++
 .../integration/TestParticipantNameCollision.java  |   30 ++++++-----
 .../apache/helix/integration/TestPauseSignal.java  |   19 +++++++
 .../helix/integration/TestRenamePartition.java     |   30 ++++++-----
 .../helix/integration/TestResetInstance.java       |   19 +++++++
 .../helix/integration/TestResetPartitionState.java |   30 ++++++-----
 .../helix/integration/TestResetResource.java       |   19 +++++++
 .../helix/integration/TestRestartParticipant.java  |   19 +++++++
 .../helix/integration/TestSchedulerMessage.java    |   30 ++++++-----
 .../apache/helix/integration/TestSchemataSM.java   |   19 +++++++
 .../integration/TestSessionExpiryInTransition.java |   19 +++++++
 .../helix/integration/TestStandAloneCMMain.java    |   30 ++++++-----
 .../integration/TestStandAloneCMSessionExpiry.java |   30 ++++++-----
 .../integration/TestStateTransitionTimeout.java    |   19 +++++++
 .../apache/helix/integration/TestStatusUpdate.java |   30 ++++++-----
 .../apache/helix/integration/TestSwapInstance.java |   19 +++++++
 .../helix/integration/ZkIntegrationTestBase.java   |   30 ++++++-----
 .../helix/integration/ZkStandAloneCMTestBase.java  |   30 ++++++-----
 ...tandAloneCMTestBaseWithPropertyServerCheck.java |   30 ++++++-----
 .../josql/TestClusterJosqlQueryProcessor.java      |   30 ++++++-----
 .../org/apache/helix/josql/TestJosqlProcessor.java |   30 ++++++-----
 .../org/apache/helix/manager/MockListener.java     |   30 ++++++-----
 .../helix/manager/file/MockFileHelixManager.java   |   30 ++++++-----
 .../manager/file/TestFileCallbackHandler.java      |   30 ++++++-----
 .../helix/manager/file/TestFileDataAccessor.java   |   30 ++++++-----
 .../helix/manager/file/TestStaticFileCM.java       |   30 ++++++-----
 .../manager/file/UnitTestDynFileClusterMgr.java    |   30 ++++++-----
 .../zk/TestDefaultControllerMsgHandlerFactory.java |   30 ++++++-----
 .../helix/manager/zk/TestHandleNewSession.java     |   19 +++++++
 .../helix/manager/zk/TestLiveInstanceBounce.java   |   30 ++++++-----
 .../manager/zk/TestWtCacheAsyncOpMultiThread.java  |   19 +++++++
 .../manager/zk/TestWtCacheAsyncOpSingleThread.java |   19 +++++++
 .../manager/zk/TestWtCacheSyncOpSingleThread.java  |   19 +++++++
 .../helix/manager/zk/TestZKDataAccessor.java       |   30 ++++++-----
 .../helix/manager/zk/TestZKDataAccessorCache.java  |   30 ++++++-----
 .../helix/manager/zk/TestZKLiveInstanceData.java   |   19 +++++++
 .../manager/zk/TestZKPropertyTransferServer.java   |   19 +++++++
 .../org/apache/helix/manager/zk/TestZKUtil.java    |   30 ++++++-----
 .../helix/manager/zk/TestZNRecordSizeLimit.java    |   30 ++++++-----
 .../helix/manager/zk/TestZkBaseDataAccessor.java   |   19 +++++++
 .../manager/zk/TestZkCacheAsyncOpSingleThread.java |   19 +++++++
 .../manager/zk/TestZkCacheSyncOpSingleThread.java  |   19 +++++++
 .../helix/manager/zk/TestZkClusterManager.java     |   30 ++++++-----
 .../apache/helix/manager/zk/TestZkHelixAdmin.java  |   30 ++++++-----
 .../apache/helix/messaging/TestAsyncCallback.java  |   30 ++++++-----
 .../helix/messaging/TestAsyncCallbackSvc.java      |   30 ++++++-----
 .../messaging/TestDefaultMessagingService.java     |   30 ++++++-----
 .../handling/TestConfigThreadpoolSize.java         |   19 +++++++
 .../messaging/handling/TestHelixTaskExecutor.java  |   30 ++++++-----
 .../handling/TestResourceThreadpoolSize.java       |   19 +++++++
 .../helix/mock/consumer/ConsumerAdapter.java       |   30 ++++++-----
 .../apache/helix/mock/consumer/RelayConfig.java    |   30 ++++++-----
 .../apache/helix/mock/consumer/RelayConsumer.java  |   30 ++++++-----
 .../helix/mock/controller/ClusterController.java   |   19 +++++++
 .../helix/mock/controller/MockController.java      |   30 ++++++-----
 .../mock/controller/MockControllerProcess.java     |   30 ++++++-----
 .../apache/helix/mock/relay/DummyRelayProcess.java |   30 ++++++-----
 .../helix/mock/relay/RelayIdealStateGenerator.java |   30 ++++++-----
 .../helix/mock/router/MockRouterProcess.java       |   30 ++++++-----
 .../apache/helix/mock/router/RouterAdapter.java    |   30 ++++++-----
 .../apache/helix/mock/storage/DummyProcess.java    |   30 ++++++-----
 .../helix/mock/storage/HealthCheckStateModel.java  |   30 ++++++-----
 .../mock/storage/HealthCheckStateModelFactory.java |   30 ++++++-----
 .../storage/MockEspressoHealthReportProvider.java  |   30 ++++++-----
 .../mock/storage/MockHealthReportParticipant.java  |   30 ++++++-----
 .../org/apache/helix/mock/storage/MockJobIntf.java |   30 ++++++-----
 .../apache/helix/mock/storage/MockParticipant.java |   30 ++++++-----
 .../helix/mock/storage/MockStorageProcess.java     |   30 ++++++-----
 .../apache/helix/mock/storage/MockTransition.java  |   30 ++++++-----
 .../apache/helix/mock/storage/StorageAdapter.java  |   30 ++++++-----
 .../helix/mock/storage/StorageStateModel.java      |   30 ++++++-----
 .../mock/storage/StorageStateModelFactory.java     |   30 ++++++-----
 .../org/apache/helix/model/TestConstraint.java     |   30 ++++++-----
 .../org/apache/helix/model/TestIdealState.java     |   19 +++++++
 .../helix/monitoring/TestParticipantMonitor.java   |   30 ++++++-----
 .../apache/helix/monitoring/TestStatCollector.java |   33 ++++++------
 .../TestClusterAlertItemMBeanCollection.java       |   30 ++++++-----
 .../mbeans/TestClusterStatusMonitor.java           |   30 ++++++-----
 .../monitoring/mbeans/TestResourceMonitor.java     |   30 ++++++-----
 .../helix/participant/MockZKHelixManager.java      |   30 ++++++-----
 .../participant/TestDistControllerElection.java    |   30 ++++++-----
 .../participant/TestDistControllerStateModel.java  |   30 ++++++-----
 .../TestDistControllerStateModelFactory.java       |   30 ++++++-----
 .../org/apache/helix/store/TestJsonComparator.java |   30 ++++++-----
 .../org/apache/helix/store/TestPropertyStat.java   |   33 ++++++------
 .../helix/store/TestPropertyStoreException.java    |   33 ++++++------
 .../helix/store/TestPropertyStoreFactory.java      |   30 ++++++-----
 .../helix/store/TestZNRecordJsonSerializer.java    |   30 ++++++-----
 .../helix/store/file/TestFilePropertyStore.java    |   30 ++++++-----
 .../apache/helix/store/zk/TestZKPropertyStore.java |   30 ++++++-----
 .../store/zk/TestZKPropertyStoreMultiThread.java   |   30 ++++++-----
 .../helix/store/zk/TestZkHelixPropertyStore.java   |   19 +++++++
 .../store/zk/TestZkPropertyStoreSessionExpiry.java |   30 ++++++-----
 .../org/apache/helix/tools/TestClusterSetup.java   |   30 ++++++-----
 .../helix/tools/TestHelixAdminScenariosCli.java    |   20 ++++++++
 .../org/apache/helix/util/TestZKClientPool.java    |   30 ++++++-----
 391 files changed, 6842 insertions(+), 3691 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/c54c6163/helix-core/src/main/java/org/apache/helix/alerts/AccumulateAggregator.java
----------------------------------------------------------------------
diff --git a/helix-core/src/main/java/org/apache/helix/alerts/AccumulateAggregator.java b/helix-core/src/main/java/org/apache/helix/alerts/AccumulateAggregator.java
index 29c0c69..d9330f2 100644
--- a/helix-core/src/main/java/org/apache/helix/alerts/AccumulateAggregator.java
+++ b/helix-core/src/main/java/org/apache/helix/alerts/AccumulateAggregator.java
@@ -19,8 +19,6 @@ package org.apache.helix.alerts;
  * under the License.
  */
 
-import java.util.Iterator;
-
 import org.apache.helix.HelixException;
 
 

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/c54c6163/helix-core/src/main/java/org/apache/helix/alerts/package-info.java
----------------------------------------------------------------------
diff --git a/helix-core/src/main/java/org/apache/helix/alerts/package-info.java b/helix-core/src/main/java/org/apache/helix/alerts/package-info.java
index 5ff2e7d..bf1d9a6 100644
--- a/helix-core/src/main/java/org/apache/helix/alerts/package-info.java
+++ b/helix-core/src/main/java/org/apache/helix/alerts/package-info.java
@@ -1,3 +1,21 @@
+/*
+ * 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.
+ */
 /**
  * Classes for Helix alerts
  */

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/c54c6163/helix-core/src/main/java/org/apache/helix/controller/package-info.java
----------------------------------------------------------------------
diff --git a/helix-core/src/main/java/org/apache/helix/controller/package-info.java b/helix-core/src/main/java/org/apache/helix/controller/package-info.java
index f999c38..93a988e 100644
--- a/helix-core/src/main/java/org/apache/helix/controller/package-info.java
+++ b/helix-core/src/main/java/org/apache/helix/controller/package-info.java
@@ -1,3 +1,21 @@
+/*
+ * 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.
+ */
 /**
  * Helix cluster controller
  */

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/c54c6163/helix-core/src/main/java/org/apache/helix/controller/pipeline/package-info.java
----------------------------------------------------------------------
diff --git a/helix-core/src/main/java/org/apache/helix/controller/pipeline/package-info.java b/helix-core/src/main/java/org/apache/helix/controller/pipeline/package-info.java
index 03f31ba..e3f7acd 100644
--- a/helix-core/src/main/java/org/apache/helix/controller/pipeline/package-info.java
+++ b/helix-core/src/main/java/org/apache/helix/controller/pipeline/package-info.java
@@ -1,3 +1,21 @@
+/*
+ * 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.
+ */
 /**
  * Helix controller pipeline classes that process cluster changes
  * 

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/c54c6163/helix-core/src/main/java/org/apache/helix/controller/restlet/package-info.java
----------------------------------------------------------------------
diff --git a/helix-core/src/main/java/org/apache/helix/controller/restlet/package-info.java b/helix-core/src/main/java/org/apache/helix/controller/restlet/package-info.java
index 35e5f01..0ef7a79 100644
--- a/helix-core/src/main/java/org/apache/helix/controller/restlet/package-info.java
+++ b/helix-core/src/main/java/org/apache/helix/controller/restlet/package-info.java
@@ -1,3 +1,21 @@
+/*
+ * 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.
+ */
 /**
  * Restlet server for Helix controller
  * 

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/c54c6163/helix-core/src/main/java/org/apache/helix/controller/stages/package-info.java
----------------------------------------------------------------------
diff --git a/helix-core/src/main/java/org/apache/helix/controller/stages/package-info.java b/helix-core/src/main/java/org/apache/helix/controller/stages/package-info.java
index 6dd3780..9e056af 100644
--- a/helix-core/src/main/java/org/apache/helix/controller/stages/package-info.java
+++ b/helix-core/src/main/java/org/apache/helix/controller/stages/package-info.java
@@ -1,3 +1,21 @@
+/*
+ * 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.
+ */
 /**
  * Stages in Helix controller pipelines 
  * 

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/c54c6163/helix-core/src/main/java/org/apache/helix/examples/BootstrapHandler.java
----------------------------------------------------------------------
diff --git a/helix-core/src/main/java/org/apache/helix/examples/BootstrapHandler.java b/helix-core/src/main/java/org/apache/helix/examples/BootstrapHandler.java
index 73f0151..2a48d6a 100644
--- a/helix-core/src/main/java/org/apache/helix/examples/BootstrapHandler.java
+++ b/helix-core/src/main/java/org/apache/helix/examples/BootstrapHandler.java
@@ -1,19 +1,23 @@
-/**
- * Copyright (C) 2012 LinkedIn Inc <op...@linkedin.com>
- *
- * Licensed 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
+package org.apache.helix.examples;
+
+/*
+ * 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
+ *   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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
-package org.apache.helix.examples;
 
 import java.util.UUID;
 

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/c54c6163/helix-core/src/main/java/org/apache/helix/examples/DummyParticipant.java
----------------------------------------------------------------------
diff --git a/helix-core/src/main/java/org/apache/helix/examples/DummyParticipant.java b/helix-core/src/main/java/org/apache/helix/examples/DummyParticipant.java
index e0d048e..6bf1500 100644
--- a/helix-core/src/main/java/org/apache/helix/examples/DummyParticipant.java
+++ b/helix-core/src/main/java/org/apache/helix/examples/DummyParticipant.java
@@ -1,5 +1,24 @@
 package org.apache.helix.examples;
 
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
 import org.apache.helix.HelixManager;
 import org.apache.helix.HelixManagerFactory;
 import org.apache.helix.InstanceType;

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/c54c6163/helix-core/src/main/java/org/apache/helix/examples/ExampleHelper.java
----------------------------------------------------------------------
diff --git a/helix-core/src/main/java/org/apache/helix/examples/ExampleHelper.java b/helix-core/src/main/java/org/apache/helix/examples/ExampleHelper.java
index f27fdad..af77f02 100644
--- a/helix-core/src/main/java/org/apache/helix/examples/ExampleHelper.java
+++ b/helix-core/src/main/java/org/apache/helix/examples/ExampleHelper.java
@@ -1,5 +1,24 @@
 package org.apache.helix.examples;
 
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+
 import java.io.File;
 import java.io.IOException;
 

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/c54c6163/helix-core/src/main/java/org/apache/helix/examples/ExampleProcess.java
----------------------------------------------------------------------
diff --git a/helix-core/src/main/java/org/apache/helix/examples/ExampleProcess.java b/helix-core/src/main/java/org/apache/helix/examples/ExampleProcess.java
index 44eb75b..f374c8c 100644
--- a/helix-core/src/main/java/org/apache/helix/examples/ExampleProcess.java
+++ b/helix-core/src/main/java/org/apache/helix/examples/ExampleProcess.java
@@ -1,19 +1,23 @@
-/**
- * Copyright (C) 2012 LinkedIn Inc <op...@linkedin.com>
- *
- * Licensed 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
+package org.apache.helix.examples;
+
+/*
+ * 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
+ *   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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
-package org.apache.helix.examples;
 
 import java.io.File;
 

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/c54c6163/helix-core/src/main/java/org/apache/helix/examples/IdealStateExample.java
----------------------------------------------------------------------
diff --git a/helix-core/src/main/java/org/apache/helix/examples/IdealStateExample.java b/helix-core/src/main/java/org/apache/helix/examples/IdealStateExample.java
index f090ace..f98199d 100644
--- a/helix-core/src/main/java/org/apache/helix/examples/IdealStateExample.java
+++ b/helix-core/src/main/java/org/apache/helix/examples/IdealStateExample.java
@@ -1,15 +1,31 @@
 package org.apache.helix.examples;
 
-import java.io.File;
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
 
 import org.apache.helix.controller.HelixControllerMain;
 import org.apache.helix.manager.zk.ZKHelixAdmin;
 import org.apache.helix.manager.zk.ZNRecordSerializer;
 import org.apache.helix.manager.zk.ZkClient;
+import org.apache.helix.model.IdealState.IdealStateModeProperty;
 import org.apache.helix.model.InstanceConfig;
 import org.apache.helix.model.StateModelDefinition;
-import org.apache.helix.model.IdealState.IdealStateModeProperty;
-import org.apache.helix.tools.ClusterSetup;
 import org.apache.helix.tools.StateModelConfigGenerator;
 
 

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/c54c6163/helix-core/src/main/java/org/apache/helix/examples/LeaderStandbyStateModelFactory.java
----------------------------------------------------------------------
diff --git a/helix-core/src/main/java/org/apache/helix/examples/LeaderStandbyStateModelFactory.java b/helix-core/src/main/java/org/apache/helix/examples/LeaderStandbyStateModelFactory.java
index ec54970..f36acf9 100644
--- a/helix-core/src/main/java/org/apache/helix/examples/LeaderStandbyStateModelFactory.java
+++ b/helix-core/src/main/java/org/apache/helix/examples/LeaderStandbyStateModelFactory.java
@@ -1,19 +1,23 @@
-/**
- * Copyright (C) 2012 LinkedIn Inc <op...@linkedin.com>
- *
- * Licensed 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
+package org.apache.helix.examples;
+
+/*
+ * 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
+ *   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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
-package org.apache.helix.examples;
 
 import org.apache.helix.NotificationContext;
 import org.apache.helix.model.Message;

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/c54c6163/helix-core/src/main/java/org/apache/helix/examples/MasterSlaveStateModelFactory.java
----------------------------------------------------------------------
diff --git a/helix-core/src/main/java/org/apache/helix/examples/MasterSlaveStateModelFactory.java b/helix-core/src/main/java/org/apache/helix/examples/MasterSlaveStateModelFactory.java
index b8be32a..1a9b551 100644
--- a/helix-core/src/main/java/org/apache/helix/examples/MasterSlaveStateModelFactory.java
+++ b/helix-core/src/main/java/org/apache/helix/examples/MasterSlaveStateModelFactory.java
@@ -1,19 +1,23 @@
-/**
- * Copyright (C) 2012 LinkedIn Inc <op...@linkedin.com>
- *
- * Licensed 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
+package org.apache.helix.examples;
+
+/*
+ * 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
+ *   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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
-package org.apache.helix.examples;
 
 import org.apache.helix.NotificationContext;
 import org.apache.helix.model.Message;

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/c54c6163/helix-core/src/main/java/org/apache/helix/examples/OnlineOfflineStateModelFactory.java
----------------------------------------------------------------------
diff --git a/helix-core/src/main/java/org/apache/helix/examples/OnlineOfflineStateModelFactory.java b/helix-core/src/main/java/org/apache/helix/examples/OnlineOfflineStateModelFactory.java
index 7b9bebe..6eb3d2f 100644
--- a/helix-core/src/main/java/org/apache/helix/examples/OnlineOfflineStateModelFactory.java
+++ b/helix-core/src/main/java/org/apache/helix/examples/OnlineOfflineStateModelFactory.java
@@ -1,19 +1,23 @@
-/**
- * Copyright (C) 2012 LinkedIn Inc <op...@linkedin.com>
- *
- * Licensed 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
+package org.apache.helix.examples;
+
+/*
+ * 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
+ *   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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
-package org.apache.helix.examples;
 
 import org.apache.helix.NotificationContext;
 import org.apache.helix.model.Message;

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/c54c6163/helix-core/src/main/java/org/apache/helix/examples/package-info.java
----------------------------------------------------------------------
diff --git a/helix-core/src/main/java/org/apache/helix/examples/package-info.java b/helix-core/src/main/java/org/apache/helix/examples/package-info.java
index 0016cca..6714341 100644
--- a/helix-core/src/main/java/org/apache/helix/examples/package-info.java
+++ b/helix-core/src/main/java/org/apache/helix/examples/package-info.java
@@ -1,3 +1,21 @@
+/*
+ * 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.
+ */
 /**
  * Examples of using Helix cluster manager
  * 

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/c54c6163/helix-core/src/main/java/org/apache/helix/healthcheck/AccumulateAggregationType.java
----------------------------------------------------------------------
diff --git a/helix-core/src/main/java/org/apache/helix/healthcheck/AccumulateAggregationType.java b/helix-core/src/main/java/org/apache/helix/healthcheck/AccumulateAggregationType.java
index 3816914..eaec3a9 100644
--- a/helix-core/src/main/java/org/apache/helix/healthcheck/AccumulateAggregationType.java
+++ b/helix-core/src/main/java/org/apache/helix/healthcheck/AccumulateAggregationType.java
@@ -1,19 +1,23 @@
-/**
- * Copyright (C) 2012 LinkedIn Inc <op...@linkedin.com>
- *
- * Licensed 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
+package org.apache.helix.healthcheck;
+
+/*
+ * 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
+ *   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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
-package org.apache.helix.healthcheck;
 
 import org.apache.log4j.Logger;
 

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/c54c6163/helix-core/src/main/java/org/apache/helix/healthcheck/AggregationType.java
----------------------------------------------------------------------
diff --git a/helix-core/src/main/java/org/apache/helix/healthcheck/AggregationType.java b/helix-core/src/main/java/org/apache/helix/healthcheck/AggregationType.java
index d331a0f..cda4ef6 100644
--- a/helix-core/src/main/java/org/apache/helix/healthcheck/AggregationType.java
+++ b/helix-core/src/main/java/org/apache/helix/healthcheck/AggregationType.java
@@ -1,19 +1,23 @@
-/**
- * Copyright (C) 2012 LinkedIn Inc <op...@linkedin.com>
- *
- * Licensed 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
+package org.apache.helix.healthcheck;
+
+/*
+ * 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
+ *   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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
-package org.apache.helix.healthcheck;
 
 public interface AggregationType
 {

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/c54c6163/helix-core/src/main/java/org/apache/helix/healthcheck/AggregationTypeFactory.java
----------------------------------------------------------------------
diff --git a/helix-core/src/main/java/org/apache/helix/healthcheck/AggregationTypeFactory.java b/helix-core/src/main/java/org/apache/helix/healthcheck/AggregationTypeFactory.java
index 3e43f25..726a792 100644
--- a/helix-core/src/main/java/org/apache/helix/healthcheck/AggregationTypeFactory.java
+++ b/helix-core/src/main/java/org/apache/helix/healthcheck/AggregationTypeFactory.java
@@ -1,19 +1,23 @@
-/**
- * Copyright (C) 2012 LinkedIn Inc <op...@linkedin.com>
- *
- * Licensed 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
+package org.apache.helix.healthcheck;
+
+/*
+ * 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
+ *   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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
-package org.apache.helix.healthcheck;
 
 import java.util.StringTokenizer;
 

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/c54c6163/helix-core/src/main/java/org/apache/helix/healthcheck/DecayAggregationType.java
----------------------------------------------------------------------
diff --git a/helix-core/src/main/java/org/apache/helix/healthcheck/DecayAggregationType.java b/helix-core/src/main/java/org/apache/helix/healthcheck/DecayAggregationType.java
index 6cec7f8..2ace6c4 100644
--- a/helix-core/src/main/java/org/apache/helix/healthcheck/DecayAggregationType.java
+++ b/helix-core/src/main/java/org/apache/helix/healthcheck/DecayAggregationType.java
@@ -1,21 +1,23 @@
-/**
- * Copyright (C) 2012 LinkedIn Inc <op...@linkedin.com>
- *
- * Licensed 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
+package org.apache.helix.healthcheck;
+
+/*
+ * 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
+ *   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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
-package org.apache.helix.healthcheck;
-
-import java.util.TimerTask;
 
 import org.apache.log4j.Logger;
 

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/c54c6163/helix-core/src/main/java/org/apache/helix/healthcheck/DefaultHealthReportProvider.java
----------------------------------------------------------------------
diff --git a/helix-core/src/main/java/org/apache/helix/healthcheck/DefaultHealthReportProvider.java b/helix-core/src/main/java/org/apache/helix/healthcheck/DefaultHealthReportProvider.java
index ae262eb..7909ce3 100644
--- a/helix-core/src/main/java/org/apache/helix/healthcheck/DefaultHealthReportProvider.java
+++ b/helix-core/src/main/java/org/apache/helix/healthcheck/DefaultHealthReportProvider.java
@@ -1,19 +1,23 @@
-/**
- * Copyright (C) 2012 LinkedIn Inc <op...@linkedin.com>
- *
- * Licensed 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
+package org.apache.helix.healthcheck;
+
+/*
+ * 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
+ *   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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
-package org.apache.helix.healthcheck;
 
 import java.lang.management.ManagementFactory;
 import java.lang.management.OperatingSystemMXBean;

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/c54c6163/helix-core/src/main/java/org/apache/helix/healthcheck/DefaultPerfCounters.java
----------------------------------------------------------------------
diff --git a/helix-core/src/main/java/org/apache/helix/healthcheck/DefaultPerfCounters.java b/helix-core/src/main/java/org/apache/helix/healthcheck/DefaultPerfCounters.java
index cbc9938..561966e 100644
--- a/helix-core/src/main/java/org/apache/helix/healthcheck/DefaultPerfCounters.java
+++ b/helix-core/src/main/java/org/apache/helix/healthcheck/DefaultPerfCounters.java
@@ -1,19 +1,23 @@
-/**
- * Copyright (C) 2012 LinkedIn Inc <op...@linkedin.com>
- *
- * Licensed 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
+package org.apache.helix.healthcheck;
+
+/*
+ * 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
+ *   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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
-package org.apache.helix.healthcheck;
 
 import java.util.Date;
 

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/c54c6163/helix-core/src/main/java/org/apache/helix/healthcheck/HealthReportProvider.java
----------------------------------------------------------------------
diff --git a/helix-core/src/main/java/org/apache/helix/healthcheck/HealthReportProvider.java b/helix-core/src/main/java/org/apache/helix/healthcheck/HealthReportProvider.java
index 1725208..d445f80 100644
--- a/helix-core/src/main/java/org/apache/helix/healthcheck/HealthReportProvider.java
+++ b/helix-core/src/main/java/org/apache/helix/healthcheck/HealthReportProvider.java
@@ -1,19 +1,23 @@
-/**
- * Copyright (C) 2012 LinkedIn Inc <op...@linkedin.com>
- *
- * Licensed 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
+package org.apache.helix.healthcheck;
+
+/*
+ * 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
+ *   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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
-package org.apache.helix.healthcheck;
 
 import java.util.Map;
 

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/c54c6163/helix-core/src/main/java/org/apache/helix/healthcheck/HealthStatsAggregationTask.java
----------------------------------------------------------------------
diff --git a/helix-core/src/main/java/org/apache/helix/healthcheck/HealthStatsAggregationTask.java b/helix-core/src/main/java/org/apache/helix/healthcheck/HealthStatsAggregationTask.java
index 136ae63..785b190 100644
--- a/helix-core/src/main/java/org/apache/helix/healthcheck/HealthStatsAggregationTask.java
+++ b/helix-core/src/main/java/org/apache/helix/healthcheck/HealthStatsAggregationTask.java
@@ -1,19 +1,23 @@
-/**
- * Copyright (C) 2012 LinkedIn Inc <op...@linkedin.com>
- *
- * Licensed 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
+package org.apache.helix.healthcheck;
+
+/*
+ * 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
+ *   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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
-package org.apache.helix.healthcheck;
 
 import java.util.HashMap;
 import java.util.List;

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/c54c6163/helix-core/src/main/java/org/apache/helix/healthcheck/ParticipantHealthReportCollector.java
----------------------------------------------------------------------
diff --git a/helix-core/src/main/java/org/apache/helix/healthcheck/ParticipantHealthReportCollector.java b/helix-core/src/main/java/org/apache/helix/healthcheck/ParticipantHealthReportCollector.java
index 55e05fc..86ef673 100644
--- a/helix-core/src/main/java/org/apache/helix/healthcheck/ParticipantHealthReportCollector.java
+++ b/helix-core/src/main/java/org/apache/helix/healthcheck/ParticipantHealthReportCollector.java
@@ -1,19 +1,23 @@
-/**
- * Copyright (C) 2012 LinkedIn Inc <op...@linkedin.com>
- *
- * Licensed 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
+package org.apache.helix.healthcheck;
+
+/*
+ * 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
+ *   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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
-package org.apache.helix.healthcheck;
 
 import org.apache.helix.ZNRecord;
 

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/c54c6163/helix-core/src/main/java/org/apache/helix/healthcheck/ParticipantHealthReportCollectorImpl.java
----------------------------------------------------------------------
diff --git a/helix-core/src/main/java/org/apache/helix/healthcheck/ParticipantHealthReportCollectorImpl.java b/helix-core/src/main/java/org/apache/helix/healthcheck/ParticipantHealthReportCollectorImpl.java
index 3174ce5..1b337fd 100644
--- a/helix-core/src/main/java/org/apache/helix/healthcheck/ParticipantHealthReportCollectorImpl.java
+++ b/helix-core/src/main/java/org/apache/helix/healthcheck/ParticipantHealthReportCollectorImpl.java
@@ -1,19 +1,23 @@
-/**
- * Copyright (C) 2012 LinkedIn Inc <op...@linkedin.com>
- *
- * Licensed 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
+package org.apache.helix.healthcheck;
+
+/*
+ * 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
+ *   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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
-package org.apache.helix.healthcheck;
 
 import java.util.LinkedList;
 import java.util.Map;

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/c54c6163/helix-core/src/main/java/org/apache/helix/healthcheck/PerformanceHealthReportProvider.java
----------------------------------------------------------------------
diff --git a/helix-core/src/main/java/org/apache/helix/healthcheck/PerformanceHealthReportProvider.java b/helix-core/src/main/java/org/apache/helix/healthcheck/PerformanceHealthReportProvider.java
index 64229a8..3e82e93 100644
--- a/helix-core/src/main/java/org/apache/helix/healthcheck/PerformanceHealthReportProvider.java
+++ b/helix-core/src/main/java/org/apache/helix/healthcheck/PerformanceHealthReportProvider.java
@@ -1,19 +1,23 @@
-/**
- * Copyright (C) 2012 LinkedIn Inc <op...@linkedin.com>
- *
- * Licensed 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
+package org.apache.helix.healthcheck;
+
+/*
+ * 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
+ *   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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
-package org.apache.helix.healthcheck;
 
 import java.util.HashMap;
 import java.util.Map;

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/c54c6163/helix-core/src/main/java/org/apache/helix/healthcheck/Stat.java
----------------------------------------------------------------------
diff --git a/helix-core/src/main/java/org/apache/helix/healthcheck/Stat.java b/helix-core/src/main/java/org/apache/helix/healthcheck/Stat.java
index 9629fe9..ec3b236 100644
--- a/helix-core/src/main/java/org/apache/helix/healthcheck/Stat.java
+++ b/helix-core/src/main/java/org/apache/helix/healthcheck/Stat.java
@@ -1,29 +1,28 @@
-/**
- * Copyright (C) 2012 LinkedIn Inc <op...@linkedin.com>
- *
- * Licensed 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
+package org.apache.helix.healthcheck;
+
+/*
+ * 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
+ *   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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
-package org.apache.helix.healthcheck;
-
-import java.io.ByteArrayInputStream;
-import java.io.ByteArrayOutputStream;
-import java.io.IOException;
-import java.io.ObjectInputStream;
-import java.io.ObjectOutputStream;
-import java.util.Map;
 
 import org.apache.log4j.Logger;
 
+import java.util.Map;
+
 public class Stat
 {
 

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/c54c6163/helix-core/src/main/java/org/apache/helix/healthcheck/StatHealthReportProvider.java
----------------------------------------------------------------------
diff --git a/helix-core/src/main/java/org/apache/helix/healthcheck/StatHealthReportProvider.java b/helix-core/src/main/java/org/apache/helix/healthcheck/StatHealthReportProvider.java
index e4ee622..772110c 100644
--- a/helix-core/src/main/java/org/apache/helix/healthcheck/StatHealthReportProvider.java
+++ b/helix-core/src/main/java/org/apache/helix/healthcheck/StatHealthReportProvider.java
@@ -1,29 +1,31 @@
-/**
- * Copyright (C) 2012 LinkedIn Inc <op...@linkedin.com>
- *
- * Licensed 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
+package org.apache.helix.healthcheck;
+
+/*
+ * 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
+ *   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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
-package org.apache.helix.healthcheck;
+
+import org.apache.log4j.Logger;
 
 import java.util.HashMap;
-import java.util.HashSet;
 import java.util.Map;
 import java.util.Set;
-import java.util.TreeMap;
 import java.util.concurrent.ConcurrentHashMap;
 
-import org.apache.log4j.Logger;
-
 public class StatHealthReportProvider extends HealthReportProvider
 {
 

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/c54c6163/helix-core/src/main/java/org/apache/helix/healthcheck/WindowAggregationType.java
----------------------------------------------------------------------
diff --git a/helix-core/src/main/java/org/apache/helix/healthcheck/WindowAggregationType.java b/helix-core/src/main/java/org/apache/helix/healthcheck/WindowAggregationType.java
index 3db4382..e63c8ab 100644
--- a/helix-core/src/main/java/org/apache/helix/healthcheck/WindowAggregationType.java
+++ b/helix-core/src/main/java/org/apache/helix/healthcheck/WindowAggregationType.java
@@ -1,21 +1,23 @@
-/**
- * Copyright (C) 2012 LinkedIn Inc <op...@linkedin.com>
- *
- * Licensed 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
+package org.apache.helix.healthcheck;
+
+/*
+ * 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
+ *   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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
-package org.apache.helix.healthcheck;
-
-import java.util.TimerTask;
 
 import org.apache.log4j.Logger;
 

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/c54c6163/helix-core/src/main/java/org/apache/helix/healthcheck/package-info.java
----------------------------------------------------------------------
diff --git a/helix-core/src/main/java/org/apache/helix/healthcheck/package-info.java b/helix-core/src/main/java/org/apache/helix/healthcheck/package-info.java
index 3aa4e53..f584b5b 100644
--- a/helix-core/src/main/java/org/apache/helix/healthcheck/package-info.java
+++ b/helix-core/src/main/java/org/apache/helix/healthcheck/package-info.java
@@ -1,3 +1,21 @@
+/*
+ * 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.
+ */
 /**
  * Helix health check classes
  * 

http://git-wip-us.apache.org/repos/asf/incubator-helix/blob/c54c6163/helix-core/src/main/java/org/apache/helix/josql/ClusterJosqlQueryProcessor.java
----------------------------------------------------------------------
diff --git a/helix-core/src/main/java/org/apache/helix/josql/ClusterJosqlQueryProcessor.java b/helix-core/src/main/java/org/apache/helix/josql/ClusterJosqlQueryProcessor.java
index 9a5f36d..c1ed70c 100644
--- a/helix-core/src/main/java/org/apache/helix/josql/ClusterJosqlQueryProcessor.java
+++ b/helix-core/src/main/java/org/apache/helix/josql/ClusterJosqlQueryProcessor.java
@@ -1,19 +1,23 @@
-/**
- * Copyright (C) 2012 LinkedIn Inc <op...@linkedin.com>
- *
- * Licensed 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
+package org.apache.helix.josql;
+
+/*
+ * 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
+ *   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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
-package org.apache.helix.josql;
 
 import java.util.ArrayList;
 import java.util.HashMap;