You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@samoa.apache.org by gd...@apache.org on 2015/03/30 10:09:26 UTC

[4/4] incubator-samoa git commit: SAMOA-19: Update info in pom.xml Fixes #10

SAMOA-19: Update info in pom.xml
Fixes #10


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

Branch: refs/heads/master
Commit: 94f6f7652ad19c0160622a5d34cfa80119cca07a
Parents: 131f0b6
Author: Gianmarco De Francisci Morales <gd...@apache.org>
Authored: Mon Mar 30 11:08:31 2015 +0300
Committer: Gianmarco De Francisci Morales <gd...@apache.org>
Committed: Mon Mar 30 11:08:31 2015 +0300

----------------------------------------------------------------------
 bin/run-class.sh                                | 18 +------
 bin/run-container.sh                            | 18 +------
 bin/s4-build/gradle-wrapper-1.4.properties      |  2 +-
 bin/samoa-s4.properties                         |  2 +-
 bin/samoa-samza.properties                      |  2 +-
 bin/samoa-storm.properties                      |  2 +-
 bin/samza-dist/run-am.sh                        | 18 +------
 bin/samza-dist/run-class.sh                     | 18 +------
 bin/samza-dist/run-container.sh                 | 18 +------
 bin/samza-dist/run-job.sh                       | 18 +------
 pom.xml                                         | 51 +++++++++++---------
 samoa-api/pom.xml                               | 32 +++++++-----
 .../com/yahoo/labs/samoa/core/ContentEvent.java |  2 +-
 .../com/yahoo/labs/samoa/core/DoubleVector.java |  2 +-
 .../labs/samoa/core/EntranceProcessor.java      |  2 +-
 .../java/com/yahoo/labs/samoa/core/Globals.java |  2 +-
 .../com/yahoo/labs/samoa/core/Processor.java    |  2 +-
 .../labs/samoa/core/SerializableInstance.java   |  4 +-
 ...BasicClassificationPerformanceEvaluator.java |  2 +-
 .../BasicRegressionPerformanceEvaluator.java    |  2 +-
 .../ClassificationPerformanceEvaluator.java     |  2 +-
 .../ClusteringEvaluationContentEvent.java       |  2 +-
 .../ClusteringEvaluatorProcessor.java           |  2 +-
 .../ClusteringResultContentEvent.java           |  2 +-
 .../samoa/evaluation/EvaluatorProcessor.java    |  2 +-
 .../samoa/evaluation/PerformanceEvaluator.java  |  2 +-
 .../RegressionPerformanceEvaluator.java         |  2 +-
 ...indowClassificationPerformanceEvaluator.java |  2 +-
 .../labs/samoa/evaluation/measures/CMM.java     |  2 +-
 .../evaluation/measures/CMM_GTAnalysis.java     |  2 +-
 .../evaluation/measures/EntropyCollection.java  |  2 +-
 .../labs/samoa/evaluation/measures/F1.java      |  2 +-
 .../labs/samoa/evaluation/measures/General.java |  2 +-
 .../labs/samoa/evaluation/measures/SSQ.java     |  2 +-
 .../samoa/evaluation/measures/Separation.java   |  2 +-
 .../measures/SilhouetteCoefficient.java         |  2 +-
 .../measures/StatisticalCollection.java         |  2 +-
 .../samoa/examples/HelloWorldContentEvent.java  |  4 +-
 .../HelloWorldDestinationProcessor.java         |  2 +-
 .../examples/HelloWorldSourceProcessor.java     |  2 +-
 .../labs/samoa/examples/HelloWorldTask.java     |  2 +-
 .../labs/samoa/learners/AdaptiveLearner.java    |  2 +-
 .../samoa/learners/ClassificationLearner.java   |  2 +-
 .../samoa/learners/InstanceContentEvent.java    |  2 +-
 .../samoa/learners/InstancesContentEvent.java   |  2 +-
 .../com/yahoo/labs/samoa/learners/Learner.java  |  2 +-
 .../labs/samoa/learners/RegressionLearner.java  |  2 +-
 .../labs/samoa/learners/ResultContentEvent.java |  2 +-
 .../learners/classifiers/LocalLearner.java      |  2 +-
 .../classifiers/LocalLearnerProcessor.java      |  2 +-
 .../samoa/learners/classifiers/NaiveBayes.java  |  2 +-
 .../classifiers/SimpleClassifierAdapter.java    |  2 +-
 .../learners/classifiers/SingleClassifier.java  |  2 +-
 .../classifiers/ensemble/AdaptiveBagging.java   |  2 +-
 .../learners/classifiers/ensemble/Bagging.java  |  2 +-
 .../ensemble/BaggingDistributorProcessor.java   |  2 +-
 .../learners/classifiers/ensemble/Boosting.java |  2 +-
 .../ensemble/BoostingDistributorProcessor.java  |  2 +-
 .../BoostingPredictionCombinerProcessor.java    |  2 +-
 .../ensemble/PredictionCombinerProcessor.java   |  2 +-
 .../classifiers/rules/AMRulesRegressor.java     |  4 +-
 .../rules/HorizontalAMRulesRegressor.java       |  2 +-
 .../rules/VerticalAMRulesRegressor.java         |  2 +-
 .../centralized/AMRulesRegressorProcessor.java  |  2 +-
 .../classifiers/rules/common/ActiveRule.java    |  2 +-
 .../classifiers/rules/common/LearningRule.java  |  2 +-
 .../rules/common/NonLearningRule.java           |  2 +-
 .../classifiers/rules/common/PassiveRule.java   |  2 +-
 .../classifiers/rules/common/Perceptron.java    |  2 +-
 .../learners/classifiers/rules/common/Rule.java |  2 +-
 .../rules/common/RuleActiveLearningNode.java    |  2 +-
 .../rules/common/RuleActiveRegressionNode.java  |  2 +-
 .../rules/common/RulePassiveLearningNode.java   |  2 +-
 .../rules/common/RulePassiveRegressionNode.java |  2 +-
 .../rules/common/RuleRegressionNode.java        |  2 +-
 .../classifiers/rules/common/RuleSplitNode.java |  2 +-
 .../classifiers/rules/common/TargetMean.java    |  2 +-
 .../distributed/AMRDefaultRuleProcessor.java    |  2 +-
 .../rules/distributed/AMRLearnerProcessor.java  |  2 +-
 .../rules/distributed/AMRRuleSetProcessor.java  |  2 +-
 .../distributed/AMRulesAggregatorProcessor.java |  2 +-
 .../distributed/AMRulesStatisticsProcessor.java |  2 +-
 .../distributed/AssignmentContentEvent.java     |  2 +-
 .../distributed/PredicateContentEvent.java      |  2 +-
 .../rules/distributed/RuleContentEvent.java     |  2 +-
 .../classifiers/trees/ActiveLearningNode.java   |  2 +-
 .../trees/AttributeBatchContentEvent.java       |  2 +-
 .../trees/AttributeContentEvent.java            |  2 +-
 .../classifiers/trees/ComputeContentEvent.java  |  2 +-
 .../classifiers/trees/ControlContentEvent.java  |  2 +-
 .../classifiers/trees/DeleteContentEvent.java   |  2 +-
 .../classifiers/trees/FilterProcessor.java      |  2 +-
 .../learners/classifiers/trees/FoundNode.java   |  4 +-
 .../classifiers/trees/InactiveLearningNode.java |  2 +-
 .../classifiers/trees/LearningNode.java         |  2 +-
 .../trees/LocalResultContentEvent.java          |  2 +-
 .../trees/LocalStatisticsProcessor.java         |  2 +-
 .../trees/ModelAggregatorProcessor.java         |  2 +-
 .../samoa/learners/classifiers/trees/Node.java  |  2 +-
 .../learners/classifiers/trees/SplitNode.java   |  2 +-
 .../trees/VerticalHoeffdingTree.java            |  2 +-
 .../clusterers/ClusteringContentEvent.java      |  2 +-
 .../clusterers/ClustreamClustererAdapter.java   |  2 +-
 .../clusterers/LocalClustererAdapter.java       |  2 +-
 .../clusterers/LocalClustererProcessor.java     |  2 +-
 .../learners/clusterers/SingleLearner.java      |  2 +-
 .../simple/ClusteringDistributorProcessor.java  |  2 +-
 .../clusterers/simple/DistributedClusterer.java |  2 +-
 .../yahoo/labs/samoa/moa/AbstractMOAObject.java |  2 +-
 .../com/yahoo/labs/samoa/moa/MOAObject.java     |  2 +-
 .../moa/classifiers/AbstractClassifier.java     |  2 +-
 .../labs/samoa/moa/classifiers/Classifier.java  |  2 +-
 .../labs/samoa/moa/classifiers/Regressor.java   |  2 +-
 .../core/AttributeSplitSuggestion.java          |  2 +-
 .../AttributeClassObserver.java                 |  2 +-
 ...BinaryTreeNumericAttributeClassObserver.java |  2 +-
 ...NumericAttributeClassObserverRegression.java |  2 +-
 .../DiscreteAttributeClassObserver.java         |  2 +-
 .../FIMTDDNumericAttributeClassObserver.java    |  2 +-
 .../GaussianNumericAttributeClassObserver.java  |  2 +-
 ...waldKhannaNumericAttributeClassObserver.java |  2 +-
 .../NominalAttributeClassObserver.java          |  2 +-
 .../NullAttributeClassObserver.java             |  2 +-
 .../NumericAttributeClassObserver.java          |  2 +-
 .../VFMLNumericAttributeClassObserver.java      |  2 +-
 .../InstanceConditionalBinaryTest.java          |  2 +-
 .../InstanceConditionalTest.java                |  2 +-
 .../NominalAttributeBinaryTest.java             |  2 +-
 .../NominalAttributeMultiwayTest.java           |  2 +-
 .../NumericAttributeBinaryTest.java             |  2 +-
 .../classifiers/core/driftdetection/ADWIN.java  |  2 +-
 .../driftdetection/ADWINChangeDetector.java     |  2 +-
 .../driftdetection/AbstractChangeDetector.java  |  4 +-
 .../core/driftdetection/ChangeDetector.java     |  4 +-
 .../core/driftdetection/CusumDM.java            |  4 +-
 .../classifiers/core/driftdetection/DDM.java    |  4 +-
 .../classifiers/core/driftdetection/EDDM.java   |  4 +-
 .../core/driftdetection/EWMAChartDM.java        |  4 +-
 .../GeometricMovingAverageDM.java               |  4 +-
 .../core/driftdetection/PageHinkleyDM.java      |  4 +-
 .../core/splitcriteria/GiniSplitCriterion.java  |  2 +-
 .../splitcriteria/InfoGainSplitCriterion.java   |  2 +-
 .../InfoGainSplitCriterionMultilabel.java       |  2 +-
 .../core/splitcriteria/SDRSplitCriterion.java   |  2 +-
 .../core/splitcriteria/SplitCriterion.java      |  2 +-
 .../VarianceReductionSplitCriterion.java        |  2 +-
 .../classifiers/functions/MajorityClass.java    |  2 +-
 .../moa/classifiers/rules/core/Predicate.java   |  2 +-
 ...IMTDDNumericAttributeClassLimitObserver.java |  4 +-
 .../NumericAttributeBinaryRulePredicate.java    |  2 +-
 .../splitcriteria/SDRSplitCriterionAMRules.java |  2 +-
 .../core/voting/AbstractErrorWeightedVote.java  |  2 +-
 .../rules/core/voting/ErrorWeightedVote.java    |  2 +-
 .../core/voting/InverseErrorWeightedVote.java   |  2 +-
 .../rules/core/voting/UniformWeightedVote.java  |  2 +-
 .../rules/driftdetection/PageHinkleyFading.java |  4 +-
 .../rules/driftdetection/PageHinkleyTest.java   |  4 +-
 .../yahoo/labs/samoa/moa/cluster/CFCluster.java |  2 +-
 .../yahoo/labs/samoa/moa/cluster/Cluster.java   |  2 +-
 .../labs/samoa/moa/cluster/Clustering.java      |  2 +-
 .../yahoo/labs/samoa/moa/cluster/Miniball.java  |  2 +-
 .../labs/samoa/moa/cluster/SphereCluster.java   |  2 +-
 .../samoa/moa/clusterers/AbstractClusterer.java |  2 +-
 .../samoa/moa/clusterers/ClusterGenerator.java  |  2 +-
 .../labs/samoa/moa/clusterers/Clusterer.java    |  2 +-
 .../yahoo/labs/samoa/moa/clusterers/KMeans.java |  2 +-
 .../moa/clusterers/clustream/Clustream.java     |  2 +-
 .../clusterers/clustream/ClustreamKernel.java   |  2 +-
 .../moa/clusterers/clustream/WithKmeans.java    |  2 +-
 .../labs/samoa/moa/core/AutoClassDiscovery.java |  2 +-
 .../labs/samoa/moa/core/AutoExpandVector.java   |  2 +-
 .../yahoo/labs/samoa/moa/core/DataPoint.java    |  2 +-
 .../yahoo/labs/samoa/moa/core/DoubleVector.java |  2 +-
 .../com/yahoo/labs/samoa/moa/core/Example.java  |  2 +-
 .../yahoo/labs/samoa/moa/core/FastVector.java   |  2 +-
 .../labs/samoa/moa/core/GaussianEstimator.java  |  2 +-
 .../core/GreenwaldKhannaQuantileSummary.java    |  2 +-
 .../moa/core/InputStreamProgressMonitor.java    |  2 +-
 .../labs/samoa/moa/core/InstanceExample.java    |  2 +-
 .../yahoo/labs/samoa/moa/core/Measurement.java  |  2 +-
 .../yahoo/labs/samoa/moa/core/MiscUtils.java    |  2 +-
 .../labs/samoa/moa/core/ObjectRepository.java   |  2 +-
 .../labs/samoa/moa/core/SerializeUtils.java     |  2 +-
 .../yahoo/labs/samoa/moa/core/Statistics.java   |  2 +-
 .../yahoo/labs/samoa/moa/core/StringUtils.java  |  2 +-
 .../com/yahoo/labs/samoa/moa/core/Utils.java    |  2 +-
 .../samoa/moa/evaluation/LearningCurve.java     |  2 +-
 .../moa/evaluation/LearningEvaluation.java      |  2 +-
 .../LearningPerformanceEvaluator.java           |  2 +-
 .../samoa/moa/evaluation/MeasureCollection.java |  2 +-
 .../samoa/moa/evaluation/MembershipMatrix.java  |  2 +-
 .../yahoo/labs/samoa/moa/learners/Learner.java  |  2 +-
 .../samoa/moa/options/AbstractClassOption.java  |  2 +-
 .../moa/options/AbstractOptionHandler.java      |  2 +-
 .../labs/samoa/moa/options/ClassOption.java     |  2 +-
 .../labs/samoa/moa/options/OptionHandler.java   |  2 +-
 .../labs/samoa/moa/options/OptionsHandler.java  |  2 +-
 .../labs/samoa/moa/streams/ArffFileStream.java  |  2 +-
 .../labs/samoa/moa/streams/ExampleStream.java   |  2 +-
 .../labs/samoa/moa/streams/InstanceStream.java  |  2 +-
 .../moa/streams/clustering/ClusterEvent.java    |  2 +-
 .../clustering/ClusterEventListener.java        |  2 +-
 .../streams/clustering/ClusteringStream.java    |  2 +-
 .../clustering/RandomRBFGeneratorEvents.java    |  2 +-
 .../streams/generators/HyperplaneGenerator.java |  2 +-
 .../streams/generators/RandomTreeGenerator.java |  2 +-
 .../yahoo/labs/samoa/moa/tasks/NullMonitor.java |  2 +-
 .../samoa/moa/tasks/ResultPreviewListener.java  |  2 +-
 .../com/yahoo/labs/samoa/moa/tasks/Task.java    |  2 +-
 .../yahoo/labs/samoa/moa/tasks/TaskMonitor.java |  2 +-
 .../labs/samoa/streams/ArffFileStream.java      |  2 +-
 .../streams/ClusteringEntranceProcessor.java    |  2 +-
 .../yahoo/labs/samoa/streams/FileStream.java    |  2 +-
 .../streams/PrequentialSourceProcessor.java     |  2 +-
 .../yahoo/labs/samoa/streams/StreamSource.java  |  2 +-
 .../samoa/streams/StreamSourceProcessor.java    |  2 +-
 .../labs/samoa/streams/fs/FileStreamSource.java |  2 +-
 .../samoa/streams/fs/HDFSFileStreamSource.java  |  2 +-
 .../samoa/streams/fs/LocalFileStreamSource.java |  2 +-
 .../labs/samoa/tasks/ClusteringEvaluation.java  |  2 +-
 .../labs/samoa/tasks/PrequentialEvaluation.java |  2 +-
 .../java/com/yahoo/labs/samoa/tasks/Task.java   |  4 +-
 .../AbstractEntranceProcessingItem.java         |  2 +-
 .../samoa/topology/AbstractProcessingItem.java  |  2 +-
 .../labs/samoa/topology/AbstractStream.java     |  2 +-
 .../labs/samoa/topology/AbstractTopology.java   |  2 +-
 .../labs/samoa/topology/ComponentFactory.java   |  2 +-
 .../samoa/topology/EntranceProcessingItem.java  |  4 +-
 .../labs/samoa/topology/IProcessingItem.java    |  2 +-
 .../yahoo/labs/samoa/topology/ISubmitter.java   |  2 +-
 .../topology/LocalEntranceProcessingItem.java   |  2 +-
 .../labs/samoa/topology/ProcessingItem.java     |  2 +-
 .../com/yahoo/labs/samoa/topology/Stream.java   |  4 +-
 .../com/yahoo/labs/samoa/topology/Topology.java |  2 +-
 .../labs/samoa/topology/TopologyBuilder.java    |  2 +-
 .../labs/samoa/utils/PartitioningScheme.java    |  4 +-
 .../labs/samoa/utils/StreamDestination.java     |  2 +-
 .../java/com/yahoo/labs/samoa/utils/Utils.java  |  2 +-
 .../yahoo/labs/samoa/core/DoubleVectorTest.java |  2 +-
 .../streams/fs/HDFSFileStreamSourceTest.java    |  2 +-
 .../streams/fs/LocalFileStreamSourceTest.java   |  2 +-
 samoa-instances/pom.xml                         | 16 +-----
 .../yahoo/labs/samoa/instances/ArffLoader.java  |  2 +-
 .../yahoo/labs/samoa/instances/Attribute.java   |  2 +-
 .../labs/samoa/instances/DenseInstance.java     |  2 +-
 .../labs/samoa/instances/DenseInstanceData.java |  2 +-
 .../yahoo/labs/samoa/instances/Instance.java    |  2 +-
 .../labs/samoa/instances/InstanceData.java      |  2 +-
 .../samoa/instances/InstanceInformation.java    |  2 +-
 .../yahoo/labs/samoa/instances/Instances.java   |  2 +-
 .../labs/samoa/instances/InstancesHeader.java   |  2 +-
 .../instances/SingleClassInstanceData.java      |  2 +-
 .../samoa/instances/SingleLabelInstance.java    |  2 +-
 .../labs/samoa/instances/SparseInstance.java    |  2 +-
 .../samoa/instances/SparseInstanceData.java     |  2 +-
 .../com/yahoo/labs/samoa/instances/Utils.java   |  2 +-
 samoa-local/pom.xml                             | 16 +-----
 .../java/com/yahoo/labs/samoa/LocalDoTask.java  |  2 +-
 .../topology/impl/SimpleComponentFactory.java   |  4 +-
 .../labs/samoa/topology/impl/SimpleEngine.java  |  2 +-
 .../impl/SimpleEntranceProcessingItem.java      |  2 +-
 .../topology/impl/SimpleProcessingItem.java     |  2 +-
 .../labs/samoa/topology/impl/SimpleStream.java  |  2 +-
 .../samoa/topology/impl/SimpleTopology.java     |  2 +-
 samoa-local/src/main/resources/log4j.xml        |  2 +-
 .../java/com/yahoo/labs/samoa/AlgosTest.java    |  2 +-
 .../impl/SimpleComponentFactoryTest.java        |  2 +-
 .../samoa/topology/impl/SimpleEngineTest.java   |  2 +-
 .../impl/SimpleEntranceProcessingItemTest.java  |  2 +-
 .../topology/impl/SimpleProcessingItemTest.java |  2 +-
 .../samoa/topology/impl/SimpleStreamTest.java   |  2 +-
 .../samoa/topology/impl/SimpleTopologyTest.java |  2 +-
 samoa-s4/pom.xml                                | 16 +-----
 samoa-s4/samoa-s4-adapter/pom.xml               |  4 +-
 .../samoa/topology/adapter/S4AdapterApp.java    |  2 +-
 .../adapter/S4EntranceProcessingItem.java       |  2 +-
 .../samoa/topology/adapter/package-info.java    |  2 +-
 samoa-s4/src/main/assembly/samoa-s4.xml         |  4 +-
 .../samoa/topology/impl/S4ComponentFactory.java |  2 +-
 .../labs/samoa/topology/impl/S4DoTask.java      |  2 +-
 .../topology/impl/S4EntranceProcessingItem.java |  2 +-
 .../yahoo/labs/samoa/topology/impl/S4Event.java |  2 +-
 .../samoa/topology/impl/S4ProcessingItem.java   |  2 +-
 .../labs/samoa/topology/impl/S4Stream.java      |  2 +-
 .../labs/samoa/topology/impl/S4Submitter.java   |  2 +-
 .../labs/samoa/topology/impl/S4Topology.java    |  2 +-
 .../samoa/topology/impl/SamoaSerializer.java    |  2 +-
 .../topology/impl/SamoaSerializerModule.java    |  2 +-
 samoa-samza/pom.xml                             | 16 +-----
 samoa-samza/src/main/assembly/samoa-samza.xml   |  2 +-
 .../java/com/yahoo/labs/samoa/SamzaDoTask.java  |  2 +-
 .../samoa/topology/impl/SamoaSystemFactory.java |  4 +-
 .../topology/impl/SamzaComponentFactory.java    |  4 +-
 .../labs/samoa/topology/impl/SamzaEngine.java   |  2 +-
 .../impl/SamzaEntranceProcessingItem.java       |  2 +-
 .../topology/impl/SamzaProcessingItem.java      |  4 +-
 .../topology/impl/SamzaProcessingNode.java      |  4 +-
 .../labs/samoa/topology/impl/SamzaStream.java   |  4 +-
 .../labs/samoa/topology/impl/SamzaTopology.java |  4 +-
 .../labs/samoa/utils/SamzaConfigFactory.java    |  2 +-
 .../labs/samoa/utils/SamzaKryoSerdeFactory.java |  2 +-
 .../samoa/utils/SerializableSerializer.java     |  2 +-
 .../yahoo/labs/samoa/utils/SystemsUtils.java    |  2 +-
 samoa-samza/src/main/resources/log4j.xml        |  2 +-
 samoa-storm/pom.xml                             | 16 +-----
 .../com/yahoo/labs/samoa/LocalStormDoTask.java  |  2 +-
 .../samoa/topology/impl/StormBoltStream.java    |  2 +-
 .../topology/impl/StormComponentFactory.java    |  2 +-
 .../labs/samoa/topology/impl/StormDoTask.java   |  2 +-
 .../impl/StormEntranceProcessingItem.java       |  2 +-
 .../samoa/topology/impl/StormJarSubmitter.java  |  2 +-
 .../topology/impl/StormProcessingItem.java      |  2 +-
 .../samoa/topology/impl/StormSamoaUtils.java    |  2 +-
 .../samoa/topology/impl/StormSpoutStream.java   | 40 +++++++--------
 .../labs/samoa/topology/impl/StormStream.java   |  4 +-
 .../labs/samoa/topology/impl/StormTopology.java |  2 +-
 .../samoa/topology/impl/StormTopologyNode.java  |  2 +-
 .../topology/impl/StormTopologySubmitter.java   |  2 +-
 .../java/com/yahoo/labs/samoa/AlgosTest.java    |  2 +-
 .../topology/impl/StormProcessingItemTest.java  |  2 +-
 samoa-test/pom.xml                              | 34 +++++++------
 samoa-threads/pom.xml                           | 32 +++++++-----
 322 files changed, 453 insertions(+), 594 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/bin/run-class.sh
----------------------------------------------------------------------
diff --git a/bin/run-class.sh b/bin/run-class.sh
index 8634df0..052c3b4 100644
--- a/bin/run-class.sh
+++ b/bin/run-class.sh
@@ -4,7 +4,7 @@
 # #%L
 # SAMOA
 # %%
-# Copyright (C) 2013 - 2014 Yahoo! Inc.
+# Copyright (C) 2014 - 2015 Apache Software Foundation
 # %%
 # Licensed under the Apache License, Version 2.0 (the "License");
 # you may not use this file except in compliance with the License.
@@ -19,22 +19,6 @@
 # limitations under the License.
 # #L%
 ###
-# 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.
 
 if [ $# -lt 1 ];
 then

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/bin/run-container.sh
----------------------------------------------------------------------
diff --git a/bin/run-container.sh b/bin/run-container.sh
index c46bf77..e37b74c 100644
--- a/bin/run-container.sh
+++ b/bin/run-container.sh
@@ -4,7 +4,7 @@
 # #%L
 # SAMOA
 # %%
-# Copyright (C) 2013 - 2014 Yahoo! Inc.
+# Copyright (C) 2014 - 2015 Apache Software Foundation
 # %%
 # Licensed under the Apache License, Version 2.0 (the "License");
 # you may not use this file except in compliance with the License.
@@ -19,21 +19,5 @@
 # limitations under the License.
 # #L%
 ###
-# 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 $(dirname $0)/run-class.sh org.apache.samza.container.SamzaContainer $@

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/bin/s4-build/gradle-wrapper-1.4.properties
----------------------------------------------------------------------
diff --git a/bin/s4-build/gradle-wrapper-1.4.properties b/bin/s4-build/gradle-wrapper-1.4.properties
index 8144b9b..67a14e8 100644
--- a/bin/s4-build/gradle-wrapper-1.4.properties
+++ b/bin/s4-build/gradle-wrapper-1.4.properties
@@ -2,7 +2,7 @@
 # #%L
 # SAMOA
 # %%
-# Copyright (C) 2015 Yahoo! Inc.
+# Copyright (C) 2014 - 2015 Apache Software Foundation
 # %%
 # Licensed under the Apache License, Version 2.0 (the "License");
 # you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/bin/samoa-s4.properties
----------------------------------------------------------------------
diff --git a/bin/samoa-s4.properties b/bin/samoa-s4.properties
index f31f867..5e11014 100644
--- a/bin/samoa-s4.properties
+++ b/bin/samoa-s4.properties
@@ -2,7 +2,7 @@
 # #%L
 # SAMOA
 # %%
-# Copyright (C) 2013 Yahoo! Inc.
+# Copyright (C) 2014 - 2015 Apache Software Foundation
 # %%
 # Licensed under the Apache License, Version 2.0 (the "License");
 # you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/bin/samoa-samza.properties
----------------------------------------------------------------------
diff --git a/bin/samoa-samza.properties b/bin/samoa-samza.properties
index db7804f..b68fed4 100644
--- a/bin/samoa-samza.properties
+++ b/bin/samoa-samza.properties
@@ -2,7 +2,7 @@
 # #%L
 # SAMOA
 # %%
-# Copyright (C) 2013 Yahoo! Inc.
+# Copyright (C) 2014 - 2015 Apache Software Foundation
 # %%
 # Licensed under the Apache License, Version 2.0 (the "License");
 # you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/bin/samoa-storm.properties
----------------------------------------------------------------------
diff --git a/bin/samoa-storm.properties b/bin/samoa-storm.properties
index 7feed28..cf46080 100644
--- a/bin/samoa-storm.properties
+++ b/bin/samoa-storm.properties
@@ -2,7 +2,7 @@
 # #%L
 # SAMOA
 # %%
-# Copyright (C) 2013 Yahoo! Inc.
+# Copyright (C) 2014 - 2015 Apache Software Foundation
 # %%
 # Licensed under the Apache License, Version 2.0 (the "License");
 # you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/bin/samza-dist/run-am.sh
----------------------------------------------------------------------
diff --git a/bin/samza-dist/run-am.sh b/bin/samza-dist/run-am.sh
index ad4475f..6a5357e 100644
--- a/bin/samza-dist/run-am.sh
+++ b/bin/samza-dist/run-am.sh
@@ -4,7 +4,7 @@
 # #%L
 # SAMOA
 # %%
-# Copyright (C) 2013 - 2014 Yahoo! Inc.
+# Copyright (C) 2014 - 2015 Apache Software Foundation
 # %%
 # Licensed under the Apache License, Version 2.0 (the "License");
 # you may not use this file except in compliance with the License.
@@ -19,21 +19,5 @@
 # limitations under the License.
 # #L%
 ###
-# 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 $(dirname $0)/run-class.sh org.apache.samza.job.yarn.SamzaAppMaster $@

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/bin/samza-dist/run-class.sh
----------------------------------------------------------------------
diff --git a/bin/samza-dist/run-class.sh b/bin/samza-dist/run-class.sh
index b6a1e79..8d2355c 100644
--- a/bin/samza-dist/run-class.sh
+++ b/bin/samza-dist/run-class.sh
@@ -4,7 +4,7 @@
 # #%L
 # SAMOA
 # %%
-# Copyright (C) 2013 - 2014 Yahoo! Inc.
+# Copyright (C) 2014 - 2015 Apache Software Foundation
 # %%
 # Licensed under the Apache License, Version 2.0 (the "License");
 # you may not use this file except in compliance with the License.
@@ -19,22 +19,6 @@
 # limitations under the License.
 # #L%
 ###
-# 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.
 
 if [ $# -lt 1 ];
 then

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/bin/samza-dist/run-container.sh
----------------------------------------------------------------------
diff --git a/bin/samza-dist/run-container.sh b/bin/samza-dist/run-container.sh
index c46bf77..e37b74c 100644
--- a/bin/samza-dist/run-container.sh
+++ b/bin/samza-dist/run-container.sh
@@ -4,7 +4,7 @@
 # #%L
 # SAMOA
 # %%
-# Copyright (C) 2013 - 2014 Yahoo! Inc.
+# Copyright (C) 2014 - 2015 Apache Software Foundation
 # %%
 # Licensed under the Apache License, Version 2.0 (the "License");
 # you may not use this file except in compliance with the License.
@@ -19,21 +19,5 @@
 # limitations under the License.
 # #L%
 ###
-# 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 $(dirname $0)/run-class.sh org.apache.samza.container.SamzaContainer $@

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/bin/samza-dist/run-job.sh
----------------------------------------------------------------------
diff --git a/bin/samza-dist/run-job.sh b/bin/samza-dist/run-job.sh
index e77c9af..8575912 100644
--- a/bin/samza-dist/run-job.sh
+++ b/bin/samza-dist/run-job.sh
@@ -4,7 +4,7 @@
 # #%L
 # SAMOA
 # %%
-# Copyright (C) 2013 - 2014 Yahoo! Inc.
+# Copyright (C) 2014 - 2015 Apache Software Foundation
 # %%
 # Licensed under the Apache License, Version 2.0 (the "License");
 # you may not use this file except in compliance with the License.
@@ -19,21 +19,5 @@
 # limitations under the License.
 # #L%
 ###
-# 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 $(dirname $0)/run-class.sh org.apache.samza.job.JobRunner $@

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index 88b2b46..57650c3 100644
--- a/pom.xml
+++ b/pom.xml
@@ -1,24 +1,31 @@
 <?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.
--->
+  #%L
+  SAMOA
+  %%
+  Copyright (C) 2014 - 2015 Apache Software Foundation
+  %%
+  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
+  
+       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.
+  #L%
+  -->
+
 <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">
     <modelVersion>4.0.0</modelVersion>
 
-    <name>SAMOA</name>
+    <name>Apache SAMOA</name>
     <description>Scalable Advanced Massive Online Analysis</description>
-    <url>http://github.com/yahoo/samoa</url>
+    <url>http://samoa.incubator.apache.org</url>
+    <inceptionYear>2013</inceptionYear>
     <modules>
         <module>samoa-test</module>
     </modules>
@@ -29,14 +36,14 @@
     <version>0.3.0-SNAPSHOT</version>
 
     <organization>
-        <name>Yahoo Labs</name>
-        <url>http://labs.yahoo.com</url>
+        <name>The Apache Software Foundation</name>
+        <url>http://www.apache.org</url>
     </organization>
 
     <scm>
-        <connection>scm:git:git@github.com:yahoo/samoa.git</connection>
-        <url>scm:git:git@github.com:yahoo/samoa.git</url>
-        <developerConnection>scm:git:git@github.com:yahoo/samoa.git</developerConnection>
+        <url>https://git-wip-us.apache.org/repos/asf/incubator-samoa.git</url>
+        <connection>scm:git:https://git-wip-us.apache.org/repos/asf/incubator-samoa.git</connection>
+        <developerConnection>scm:git:git://git.apache.org/incubator-samoa.git</developerConnection>
         <tag>HEAD</tag>
     </scm>
 
@@ -195,8 +202,8 @@
                 <version>1.5</version>
                 <configuration>
                     <licenseName>apache_v2</licenseName>
-                    <inceptionYear>2013</inceptionYear>
-                    <organizationName>Yahoo! Inc.</organizationName>
+                    <inceptionYear>2014</inceptionYear>
+                    <organizationName>Apache Software Foundation</organizationName>
                     <projectName>SAMOA</projectName>
                     <roots>
                         <root>samoa-api</root>

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/pom.xml
----------------------------------------------------------------------
diff --git a/samoa-api/pom.xml b/samoa-api/pom.xml
index 58937e3..de6a73d 100644
--- a/samoa-api/pom.xml
+++ b/samoa-api/pom.xml
@@ -1,18 +1,24 @@
 <?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.
--->
+  #%L
+  SAMOA
+  %%
+  Copyright (C) 2014 - 2015 Apache Software Foundation
+  %%
+  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
+  
+       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.
+  #L%
+  -->
+
 <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">
   <modelVersion>4.0.0</modelVersion>

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/core/ContentEvent.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/core/ContentEvent.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/core/ContentEvent.java
index d9bb944..0d88398 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/core/ContentEvent.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/core/ContentEvent.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.core;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/core/DoubleVector.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/core/DoubleVector.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/core/DoubleVector.java
index 6be9452..96b6c43 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/core/DoubleVector.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/core/DoubleVector.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.core;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/core/EntranceProcessor.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/core/EntranceProcessor.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/core/EntranceProcessor.java
index 2371c02..1b0cfb3 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/core/EntranceProcessor.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/core/EntranceProcessor.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.core;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/core/Globals.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/core/Globals.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/core/Globals.java
index e3435c1..c333b8e 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/core/Globals.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/core/Globals.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.core;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/core/Processor.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/core/Processor.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/core/Processor.java
index 7659b26..4e783bd 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/core/Processor.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/core/Processor.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.core;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/core/SerializableInstance.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/core/SerializableInstance.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/core/SerializableInstance.java
index 56fa127..cc888cc 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/core/SerializableInstance.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/core/SerializableInstance.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.core;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.
@@ -65,4 +65,4 @@ public class SerializableInstance extends DenseInstance {
     super(inst);
   }
 
-}
\ No newline at end of file
+}

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/BasicClassificationPerformanceEvaluator.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/BasicClassificationPerformanceEvaluator.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/BasicClassificationPerformanceEvaluator.java
index bc1d447..6a03e1d 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/BasicClassificationPerformanceEvaluator.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/BasicClassificationPerformanceEvaluator.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.evaluation;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/BasicRegressionPerformanceEvaluator.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/BasicRegressionPerformanceEvaluator.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/BasicRegressionPerformanceEvaluator.java
index b5f318e..591b1ee 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/BasicRegressionPerformanceEvaluator.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/BasicRegressionPerformanceEvaluator.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.evaluation;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/ClassificationPerformanceEvaluator.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/ClassificationPerformanceEvaluator.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/ClassificationPerformanceEvaluator.java
index 4d684f6..5ce04df 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/ClassificationPerformanceEvaluator.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/ClassificationPerformanceEvaluator.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.evaluation;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/ClusteringEvaluationContentEvent.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/ClusteringEvaluationContentEvent.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/ClusteringEvaluationContentEvent.java
index d482145..b541b2b 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/ClusteringEvaluationContentEvent.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/ClusteringEvaluationContentEvent.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.evaluation;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/ClusteringEvaluatorProcessor.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/ClusteringEvaluatorProcessor.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/ClusteringEvaluatorProcessor.java
index d8e0943..7841030 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/ClusteringEvaluatorProcessor.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/ClusteringEvaluatorProcessor.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.evaluation;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/ClusteringResultContentEvent.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/ClusteringResultContentEvent.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/ClusteringResultContentEvent.java
index 95349c7..fbb6d3b 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/ClusteringResultContentEvent.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/ClusteringResultContentEvent.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.evaluation;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/EvaluatorProcessor.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/EvaluatorProcessor.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/EvaluatorProcessor.java
old mode 100755
new mode 100644
index ed2207f..b1748ff
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/EvaluatorProcessor.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/EvaluatorProcessor.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.evaluation;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/PerformanceEvaluator.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/PerformanceEvaluator.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/PerformanceEvaluator.java
index d7837d4..60c2ffb 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/PerformanceEvaluator.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/PerformanceEvaluator.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.evaluation;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/RegressionPerformanceEvaluator.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/RegressionPerformanceEvaluator.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/RegressionPerformanceEvaluator.java
index d230cd0..dc23102 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/RegressionPerformanceEvaluator.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/RegressionPerformanceEvaluator.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.evaluation;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/WindowClassificationPerformanceEvaluator.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/WindowClassificationPerformanceEvaluator.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/WindowClassificationPerformanceEvaluator.java
index 7917a7f..11a77a0 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/WindowClassificationPerformanceEvaluator.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/WindowClassificationPerformanceEvaluator.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.evaluation;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/CMM.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/CMM.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/CMM.java
index 35184f6..5ef959a 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/CMM.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/CMM.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.evaluation.measures;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2011 RWTH Aachen University, Germany
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/CMM_GTAnalysis.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/CMM_GTAnalysis.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/CMM_GTAnalysis.java
index 6555625..e7ae848 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/CMM_GTAnalysis.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/CMM_GTAnalysis.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.evaluation.measures;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2011 RWTH Aachen University, Germany
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/EntropyCollection.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/EntropyCollection.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/EntropyCollection.java
index 1a44542..962e66a 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/EntropyCollection.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/EntropyCollection.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.evaluation.measures;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2010 RWTH Aachen University, Germany
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/F1.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/F1.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/F1.java
index f62b6bb..a31e6ce 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/F1.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/F1.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.evaluation.measures;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2010 RWTH Aachen University, Germany
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/General.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/General.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/General.java
index 287af06..c15a8f8 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/General.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/General.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.evaluation.measures;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2010 RWTH Aachen University, Germany
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/SSQ.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/SSQ.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/SSQ.java
index ac25888..175b925 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/SSQ.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/SSQ.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.evaluation.measures;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2010 RWTH Aachen University, Germany
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/Separation.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/Separation.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/Separation.java
index 1e3072b..19b3310 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/Separation.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/Separation.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.evaluation.measures;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/SilhouetteCoefficient.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/SilhouetteCoefficient.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/SilhouetteCoefficient.java
index e689b7f..146d17a 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/SilhouetteCoefficient.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/SilhouetteCoefficient.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.evaluation.measures;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2010 RWTH Aachen University, Germany
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/StatisticalCollection.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/StatisticalCollection.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/StatisticalCollection.java
index 9b5f866..8366401 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/StatisticalCollection.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/evaluation/measures/StatisticalCollection.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.evaluation.measures;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2010 RWTH Aachen University, Germany
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/examples/HelloWorldContentEvent.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/examples/HelloWorldContentEvent.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/examples/HelloWorldContentEvent.java
index 82052fd..da2585a 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/examples/HelloWorldContentEvent.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/examples/HelloWorldContentEvent.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.examples;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 - 2014 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.
@@ -66,4 +66,4 @@ public class HelloWorldContentEvent implements ContentEvent {
   public String toString() {
     return "HelloWorldContentEvent [helloWorldData=" + helloWorldData + "]";
   }
-}
\ No newline at end of file
+}

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/examples/HelloWorldDestinationProcessor.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/examples/HelloWorldDestinationProcessor.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/examples/HelloWorldDestinationProcessor.java
index b2739be..d88839e 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/examples/HelloWorldDestinationProcessor.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/examples/HelloWorldDestinationProcessor.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.examples;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 - 2014 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/examples/HelloWorldSourceProcessor.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/examples/HelloWorldSourceProcessor.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/examples/HelloWorldSourceProcessor.java
index 1f4517d..137b5de 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/examples/HelloWorldSourceProcessor.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/examples/HelloWorldSourceProcessor.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.examples;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 - 2014 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/examples/HelloWorldTask.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/examples/HelloWorldTask.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/examples/HelloWorldTask.java
index 8a3d8c7..d8d5317 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/examples/HelloWorldTask.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/examples/HelloWorldTask.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.examples;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 - 2014 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/AdaptiveLearner.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/AdaptiveLearner.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/AdaptiveLearner.java
index aa740be..139540c 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/AdaptiveLearner.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/AdaptiveLearner.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.learners;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/ClassificationLearner.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/ClassificationLearner.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/ClassificationLearner.java
index 7f1a6c9..5c5284e 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/ClassificationLearner.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/ClassificationLearner.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.learners;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 - 2014 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/InstanceContentEvent.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/InstanceContentEvent.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/InstanceContentEvent.java
index fd25736..9ff5e66 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/InstanceContentEvent.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/InstanceContentEvent.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.learners;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/InstancesContentEvent.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/InstancesContentEvent.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/InstancesContentEvent.java
index ce5937a..cbdb881 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/InstancesContentEvent.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/InstancesContentEvent.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.learners;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/Learner.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/Learner.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/Learner.java
index 4d8db02..f934279 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/Learner.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/Learner.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.learners;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/RegressionLearner.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/RegressionLearner.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/RegressionLearner.java
index 63f233e..e4c5349 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/RegressionLearner.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/RegressionLearner.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.learners;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 - 2014 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/ResultContentEvent.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/ResultContentEvent.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/ResultContentEvent.java
index cb1e317..7426d7d 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/ResultContentEvent.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/ResultContentEvent.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.learners;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/LocalLearner.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/LocalLearner.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/LocalLearner.java
index c08a8c1..9334f7e 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/LocalLearner.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/LocalLearner.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.learners.classifiers;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/LocalLearnerProcessor.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/LocalLearnerProcessor.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/LocalLearnerProcessor.java
old mode 100755
new mode 100644
index c9ecc0b..2fd0d83
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/LocalLearnerProcessor.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/LocalLearnerProcessor.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.learners.classifiers;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/NaiveBayes.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/NaiveBayes.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/NaiveBayes.java
index d0dc2c9..a96bb6f 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/NaiveBayes.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/NaiveBayes.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.learners.classifiers;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/SimpleClassifierAdapter.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/SimpleClassifierAdapter.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/SimpleClassifierAdapter.java
index e15aae0..518ffe8 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/SimpleClassifierAdapter.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/SimpleClassifierAdapter.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.learners.classifiers;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/SingleClassifier.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/SingleClassifier.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/SingleClassifier.java
index 46352e0..c998f0d 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/SingleClassifier.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/SingleClassifier.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.learners.classifiers;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/ensemble/AdaptiveBagging.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/ensemble/AdaptiveBagging.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/ensemble/AdaptiveBagging.java
index 3bdea57..e029272 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/ensemble/AdaptiveBagging.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/ensemble/AdaptiveBagging.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.learners.classifiers.ensemble;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/ensemble/Bagging.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/ensemble/Bagging.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/ensemble/Bagging.java
index 3a78933..1d507a5 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/ensemble/Bagging.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/ensemble/Bagging.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.learners.classifiers.ensemble;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/ensemble/BaggingDistributorProcessor.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/ensemble/BaggingDistributorProcessor.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/ensemble/BaggingDistributorProcessor.java
index 4f04d91..ff5aa22 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/ensemble/BaggingDistributorProcessor.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/ensemble/BaggingDistributorProcessor.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.learners.classifiers.ensemble;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/ensemble/Boosting.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/ensemble/Boosting.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/ensemble/Boosting.java
index e81c490..088cb6a 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/ensemble/Boosting.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/ensemble/Boosting.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.learners.classifiers.ensemble;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/ensemble/BoostingDistributorProcessor.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/ensemble/BoostingDistributorProcessor.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/ensemble/BoostingDistributorProcessor.java
index 78c2bd0..d509f13 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/ensemble/BoostingDistributorProcessor.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/ensemble/BoostingDistributorProcessor.java
@@ -6,7 +6,7 @@ import com.yahoo.labs.samoa.learners.InstanceContentEvent;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/ensemble/BoostingPredictionCombinerProcessor.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/ensemble/BoostingPredictionCombinerProcessor.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/ensemble/BoostingPredictionCombinerProcessor.java
index 8acbdc8..7e5fb8d 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/ensemble/BoostingPredictionCombinerProcessor.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/ensemble/BoostingPredictionCombinerProcessor.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.learners.classifiers.ensemble;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/ensemble/PredictionCombinerProcessor.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/ensemble/PredictionCombinerProcessor.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/ensemble/PredictionCombinerProcessor.java
index fff801f..e79baca 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/ensemble/PredictionCombinerProcessor.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/ensemble/PredictionCombinerProcessor.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.learners.classifiers.ensemble;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/rules/AMRulesRegressor.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/rules/AMRulesRegressor.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/rules/AMRulesRegressor.java
index 9a88a9b..18a459d 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/rules/AMRulesRegressor.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/rules/AMRulesRegressor.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.learners.classifiers.rules;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 - 2014 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.
@@ -172,4 +172,4 @@ public class AMRulesRegressor implements RegressionLearner, Configurable {
   public Set<Stream> getResultStreams() {
     return ImmutableSet.of(this.resultStream);
   }
-}
\ No newline at end of file
+}

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/rules/HorizontalAMRulesRegressor.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/rules/HorizontalAMRulesRegressor.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/rules/HorizontalAMRulesRegressor.java
index 74b3c8a..20644d7 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/rules/HorizontalAMRulesRegressor.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/rules/HorizontalAMRulesRegressor.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.learners.classifiers.rules;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 - 2014 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/rules/VerticalAMRulesRegressor.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/rules/VerticalAMRulesRegressor.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/rules/VerticalAMRulesRegressor.java
index 21294bc..08c064f 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/rules/VerticalAMRulesRegressor.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/rules/VerticalAMRulesRegressor.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.learners.classifiers.rules;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 - 2014 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/rules/centralized/AMRulesRegressorProcessor.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/rules/centralized/AMRulesRegressorProcessor.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/rules/centralized/AMRulesRegressorProcessor.java
index f8a6a90..4cf21f0 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/rules/centralized/AMRulesRegressorProcessor.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/rules/centralized/AMRulesRegressorProcessor.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.learners.classifiers.rules.centralized;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 - 2014 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/rules/common/ActiveRule.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/rules/common/ActiveRule.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/rules/common/ActiveRule.java
index 0af17e9..423de09 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/rules/common/ActiveRule.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/rules/common/ActiveRule.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.learners.classifiers.rules.common;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 - 2014 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.

http://git-wip-us.apache.org/repos/asf/incubator-samoa/blob/94f6f765/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/rules/common/LearningRule.java
----------------------------------------------------------------------
diff --git a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/rules/common/LearningRule.java b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/rules/common/LearningRule.java
index b380ae8..5ad7d76 100644
--- a/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/rules/common/LearningRule.java
+++ b/samoa-api/src/main/java/com/yahoo/labs/samoa/learners/classifiers/rules/common/LearningRule.java
@@ -4,7 +4,7 @@ package com.yahoo.labs.samoa.learners.classifiers.rules.common;
  * #%L
  * SAMOA
  * %%
- * Copyright (C) 2013 - 2014 Yahoo! Inc.
+ * Copyright (C) 2014 - 2015 Apache Software Foundation
  * %%
  * Licensed under the Apache License, Version 2.0 (the "License");
  * you may not use this file except in compliance with the License.