You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@s2graph.apache.org by st...@apache.org on 2016/03/16 02:09:27 UTC

[4/4] incubator-s2graph git commit: [S2GRAPH-4]: Update license headers in source codes.

[S2GRAPH-4]: Update license headers in source codes.

  update all source code with apache license header.

JIRA:
  [S2GRAPH-4] https://issues.apache.org/jira/browse/S2GRAPH-4

Pull Request:
  Closes #42


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

Branch: refs/heads/master
Commit: 92aaa51817d7516621cf2bba0f101949ee8c7653
Parents: b8a1521
Author: DO YUNG YOON <st...@apache.org>
Authored: Wed Mar 16 10:07:38 2016 +0900
Committer: DO YUNG YOON <st...@apache.org>
Committed: Wed Mar 16 10:07:38 2016 +0900

----------------------------------------------------------------------
 CHANGES                                         | 21 ++++++++++++++++++++
 build.sbt                                       | 19 ++++++++++++++++++
 dev_support/graph_mysql/Dockerfile              | 19 ++++++++++++++++++
 dev_support/graph_mysql/schema.sql              | 19 ++++++++++++++++++
 loader/build.sbt                                | 19 ++++++++++++++++++
 loader/loader.py                                | 16 +++++++++++++++
 loader/src/main/resources/log4j.properties      | 17 ++++++++++++++++
 .../loader/subscriber/GraphSubscriber.scala     | 19 ++++++++++++++++++
 .../loader/subscriber/TransferToHFile.scala     | 19 ++++++++++++++++++
 .../s2graph/loader/subscriber/WalLogStat.scala  | 19 ++++++++++++++++++
 .../loader/subscriber/WalLogToHDFS.scala        | 19 ++++++++++++++++++
 .../loader/subscriber/GraphSubscriberTest.scala | 19 ++++++++++++++++++
 .../loader/subscriber/TransferToHFileTest.scala | 19 ++++++++++++++++++
 s2core/build.sbt                                | 19 ++++++++++++++++++
 s2core/migrate/mysql/schema.sql                 | 19 ++++++++++++++++++
 s2core/src/main/resources/create_model.hql      | 19 ++++++++++++++++++
 s2core/src/main/resources/logback.xml           | 20 +++++++++++++++++++
 s2core/src/main/resources/reference.conf        | 19 ++++++++++++++++++
 .../scala/org/apache/s2graph/core/Edge.scala    | 19 ++++++++++++++++++
 .../apache/s2graph/core/ExceptionHandler.scala  | 19 ++++++++++++++++++
 .../scala/org/apache/s2graph/core/Graph.scala   | 19 ++++++++++++++++++
 .../org/apache/s2graph/core/GraphElement.scala  | 19 ++++++++++++++++++
 .../apache/s2graph/core/GraphExceptions.scala   | 19 ++++++++++++++++++
 .../org/apache/s2graph/core/GraphUtil.scala     | 19 ++++++++++++++++++
 .../org/apache/s2graph/core/JSONParser.scala    | 19 ++++++++++++++++++
 .../org/apache/s2graph/core/Management.scala    | 21 +++++++++++++++++++-
 .../org/apache/s2graph/core/OrderingUtil.scala  | 19 ++++++++++++++++++
 .../org/apache/s2graph/core/PostProcess.scala   | 19 ++++++++++++++++++
 .../org/apache/s2graph/core/QueryParam.scala    | 19 ++++++++++++++++++
 .../org/apache/s2graph/core/QueryResult.scala   | 19 ++++++++++++++++++
 .../scala/org/apache/s2graph/core/Vertex.scala  | 19 ++++++++++++++++++
 .../org/apache/s2graph/core/mysqls/Bucket.scala | 19 ++++++++++++++++++
 .../apache/s2graph/core/mysqls/ColumnMeta.scala | 19 ++++++++++++++++++
 .../apache/s2graph/core/mysqls/Experiment.scala | 19 ++++++++++++++++++
 .../org/apache/s2graph/core/mysqls/Label.scala  | 19 ++++++++++++++++++
 .../apache/s2graph/core/mysqls/LabelIndex.scala | 19 ++++++++++++++++++
 .../apache/s2graph/core/mysqls/LabelMeta.scala  | 19 ++++++++++++++++++
 .../org/apache/s2graph/core/mysqls/Model.scala  | 19 ++++++++++++++++++
 .../apache/s2graph/core/mysqls/Service.scala    | 19 ++++++++++++++++++
 .../s2graph/core/mysqls/ServiceColumn.scala     | 19 ++++++++++++++++++
 .../s2graph/core/parsers/WhereParser.scala      | 19 ++++++++++++++++++
 .../s2graph/core/rest/RequestParser.scala       | 19 ++++++++++++++++++
 .../apache/s2graph/core/rest/RestHandler.scala  | 19 ++++++++++++++++++
 .../s2graph/core/storage/Deserializable.scala   | 21 +++++++++++++++++++-
 .../apache/s2graph/core/storage/SKeyValue.scala | 19 ++++++++++++++++++
 .../s2graph/core/storage/Serializable.scala     | 19 ++++++++++++++++++
 .../apache/s2graph/core/storage/Storage.scala   | 19 ++++++++++++++++++
 .../core/storage/StorageDeserializable.scala    | 19 ++++++++++++++++++
 .../core/storage/StorageSerializable.scala      | 19 ++++++++++++++++++
 .../core/storage/hbase/AsynchbaseStorage.scala  | 19 ++++++++++++++++++
 .../tall/IndexEdgeDeserializable.scala          | 19 ++++++++++++++++++
 .../indexedge/tall/IndexEdgeSerializable.scala  | 19 ++++++++++++++++++
 .../wide/IndexEdgeDeserializable.scala          | 19 ++++++++++++++++++
 .../indexedge/wide/IndexEdgeSerializable.scala  | 19 ++++++++++++++++++
 .../tall/SnapshotEdgeDeserializable.scala       | 19 ++++++++++++++++++
 .../tall/SnapshotEdgeSerializable.scala         | 19 ++++++++++++++++++
 .../wide/SnapshotEdgeDeserializable.scala       | 19 ++++++++++++++++++
 .../wide/SnapshotEdgeSerializable.scala         | 19 ++++++++++++++++++
 .../serde/vertex/VertexDeserializable.scala     | 19 ++++++++++++++++++
 .../serde/vertex/VertexSerializable.scala       | 19 ++++++++++++++++++
 .../apache/s2graph/core/types/HBaseType.scala   | 21 +++++++++++++++++++-
 .../s2graph/core/types/InnerValLike.scala       | 19 ++++++++++++++++++
 .../s2graph/core/types/LabelWithDirection.scala | 19 ++++++++++++++++++
 .../apache/s2graph/core/types/VertexId.scala    | 19 ++++++++++++++++++
 .../apache/s2graph/core/types/v1/InnerVal.scala | 19 ++++++++++++++++++
 .../apache/s2graph/core/types/v2/InnerVal.scala | 19 ++++++++++++++++++
 .../apache/s2graph/core/utils/DeferCache.scala  | 19 ++++++++++++++++++
 .../apache/s2graph/core/utils/Extentions.scala  | 19 ++++++++++++++++++
 .../apache/s2graph/core/utils/FutureCache.scala | 19 ++++++++++++++++++
 .../org/apache/s2graph/core/utils/Logger.scala  | 19 ++++++++++++++++++
 .../s2graph/core/utils/SafeUpdateCache.scala    | 19 ++++++++++++++++++
 .../org/apache/s2graph/core/EdgeTest.scala      | 19 ++++++++++++++++++
 .../s2graph/core/Integrate/CrudTest.scala       | 19 ++++++++++++++++++
 .../core/Integrate/IntegrateCommon.scala        | 19 ++++++++++++++++++
 .../s2graph/core/Integrate/QueryTest.scala      | 19 ++++++++++++++++++
 .../core/Integrate/StrongLabelDeleteTest.scala  | 19 ++++++++++++++++++
 .../core/Integrate/VertexTestHelper.scala       | 19 ++++++++++++++++++
 .../core/Integrate/WeakLabelDeleteTest.scala    | 19 ++++++++++++++++++
 .../apache/s2graph/core/JsonParserTest.scala    | 19 ++++++++++++++++++
 .../apache/s2graph/core/OrderingUtilTest.scala  | 19 ++++++++++++++++++
 .../apache/s2graph/core/QueryParamTest.scala    | 19 ++++++++++++++++++
 .../org/apache/s2graph/core/TestCommon.scala    | 19 ++++++++++++++++++
 .../s2graph/core/TestCommonWithModels.scala     | 19 ++++++++++++++++++
 .../apache/s2graph/core/models/ModelTest.scala  | 19 ++++++++++++++++++
 .../s2graph/core/mysqls/ExperimentSpec.scala    | 19 ++++++++++++++++++
 .../s2graph/core/parsers/WhereParserTest.scala  | 19 ++++++++++++++++++
 .../storage/hbase/AsynchbaseStorageTest.scala   | 21 +++++++++++++++++++-
 .../core/storage/hbase/IndexEdgeTest.scala      | 21 +++++++++++++++++++-
 .../s2graph/core/types/InnerValTest.scala       | 19 ++++++++++++++++++
 s2counter_core/build.sbt                        | 19 ++++++++++++++++++
 .../org/apache/s2graph/counter/TrxLog.scala     | 19 ++++++++++++++++++
 .../counter/config/ConfigFunctions.scala        | 19 ++++++++++++++++++
 .../counter/config/S2CounterConfig.scala        | 19 ++++++++++++++++++
 .../apache/s2graph/counter/core/BytesUtil.scala | 19 ++++++++++++++++++
 .../s2graph/counter/core/ExactCounter.scala     | 19 ++++++++++++++++++
 .../apache/s2graph/counter/core/ExactKey.scala  | 19 ++++++++++++++++++
 .../s2graph/counter/core/ExactQualifier.scala   | 19 ++++++++++++++++++
 .../s2graph/counter/core/ExactStorage.scala     | 19 ++++++++++++++++++
 .../s2graph/counter/core/RankingCounter.scala   | 21 +++++++++++++++++++-
 .../s2graph/counter/core/RankingKey.scala       | 19 ++++++++++++++++++
 .../s2graph/counter/core/RankingResult.scala    | 19 ++++++++++++++++++
 .../s2graph/counter/core/RankingStorage.scala   | 19 ++++++++++++++++++
 .../s2graph/counter/core/RankingValue.scala     | 19 ++++++++++++++++++
 .../s2graph/counter/core/RateRankingValue.scala | 19 ++++++++++++++++++
 .../s2graph/counter/core/TimedQualifier.scala   | 19 ++++++++++++++++++
 .../s2graph/counter/core/v1/BytesUtilV1.scala   | 19 ++++++++++++++++++
 .../core/v1/ExactStorageAsyncHBase.scala        | 19 ++++++++++++++++++
 .../counter/core/v1/ExactStorageHBase.scala     | 19 ++++++++++++++++++
 .../counter/core/v1/RankingStorageRedis.scala   | 19 ++++++++++++++++++
 .../s2graph/counter/core/v2/BytesUtilV2.scala   | 19 ++++++++++++++++++
 .../counter/core/v2/ExactStorageGraph.scala     | 19 ++++++++++++++++++
 .../counter/core/v2/GraphOperation.scala        | 19 ++++++++++++++++++
 .../counter/core/v2/RankingStorageGraph.scala   | 19 ++++++++++++++++++
 .../s2graph/counter/decay/DecayFormula.scala    | 19 ++++++++++++++++++
 .../s2graph/counter/decay/ExpDecayFormula.scala | 19 ++++++++++++++++++
 .../s2graph/counter/helper/CounterAdmin.scala   | 19 ++++++++++++++++++
 .../counter/helper/DistributedScanner.scala     | 19 ++++++++++++++++++
 .../counter/helper/HashShardingJedis.scala      | 19 ++++++++++++++++++
 .../s2graph/counter/helper/Management.scala     | 19 ++++++++++++++++++
 .../s2graph/counter/helper/WithHBase.scala      | 19 ++++++++++++++++++
 .../s2graph/counter/helper/WithRedis.scala      | 19 ++++++++++++++++++
 .../s2graph/counter/models/CachedDBModel.scala  | 19 ++++++++++++++++++
 .../apache/s2graph/counter/models/Counter.scala | 19 ++++++++++++++++++
 .../apache/s2graph/counter/models/DBModel.scala | 19 ++++++++++++++++++
 .../org/apache/s2graph/counter/package.scala    | 19 ++++++++++++++++++
 .../s2graph/counter/util/CartesianProduct.scala | 19 ++++++++++++++++++
 .../s2graph/counter/util/CollectionCache.scala  | 19 ++++++++++++++++++
 .../s2graph/counter/util/FunctionParser.scala   | 19 ++++++++++++++++++
 .../apache/s2graph/counter/util/Hashes.scala    | 19 ++++++++++++++++++
 .../s2graph/counter/util/ReduceMapValue.scala   | 19 ++++++++++++++++++
 .../org/apache/s2graph/counter/util/Retry.scala | 19 ++++++++++++++++++
 .../s2graph/counter/util/SplitBytes.scala       | 19 ++++++++++++++++++
 .../s2graph/counter/util/UnitConverter.scala    | 19 ++++++++++++++++++
 .../src/test/resources/application.conf         | 19 ++++++++++++++++++
 .../src/test/resources/log4j.properties         | 17 ++++++++++++++++
 .../counter/core/RankingCounterSpec.scala       | 19 ++++++++++++++++++
 .../counter/models/CounterModelSpec.scala       | 19 ++++++++++++++++++
 .../s2graph/counter/models/CounterSpec.scala    | 19 ++++++++++++++++++
 s2counter_loader/build.sbt                      | 19 ++++++++++++++++++
 .../counter/loader/CounterBulkLoader.scala      | 21 +++++++++++++++++++-
 .../counter/loader/EraseDailyCounter.scala      | 19 ++++++++++++++++++
 .../counter/loader/config/StreamingConfig.scala | 19 ++++++++++++++++++
 .../loader/core/CounterEtlFunctions.scala       | 19 ++++++++++++++++++
 .../counter/loader/core/CounterEtlItem.scala    | 19 ++++++++++++++++++
 .../counter/loader/core/CounterFunctions.scala  | 19 ++++++++++++++++++
 .../counter/loader/core/DimensionProps.scala    | 19 ++++++++++++++++++
 .../loader/models/DefaultCounterModel.scala     | 19 ++++++++++++++++++
 .../counter/loader/stream/EtlStreaming.scala    | 19 ++++++++++++++++++
 .../loader/stream/ExactCounterStreaming.scala   | 19 ++++++++++++++++++
 .../loader/stream/GraphToETLStreaming.scala     | 19 ++++++++++++++++++
 .../loader/stream/RankingCounterStreaming.scala | 19 ++++++++++++++++++
 .../src/test/resources/application.conf         | 19 ++++++++++++++++++
 .../src/test/resources/log4j.properties         | 17 ++++++++++++++++
 .../loader/core/CounterEtlFunctionsSpec.scala   | 19 ++++++++++++++++++
 .../loader/core/DimensionPropsTest.scala        | 19 ++++++++++++++++++
 .../stream/ExactCounterStreamingSpec.scala      | 19 ++++++++++++++++++
 .../stream/RankingCounterStreamingSpec.scala    | 19 ++++++++++++++++++
 s2rest_netty/build.sbt                          | 19 ++++++++++++++++++
 s2rest_netty/conf/logger.xml                    | 20 +++++++++++++++++++
 s2rest_netty/conf/reference.conf                | 19 ++++++++++++++++++
 s2rest_netty/src/main/resources/reference.conf  | 19 ++++++++++++++++++
 .../org/apache/s2graph/rest/netty/Server.scala  | 19 ++++++++++++++++++
 .../apache/s2graph/rest/play/Bootstrap.scala    | 19 ++++++++++++++++++
 .../s2graph/rest/play/actors/QueueActor.scala   | 19 ++++++++++++++++++
 .../s2graph/rest/play/config/Config.scala       | 19 ++++++++++++++++++
 .../rest/play/config/CounterConfig.scala        | 19 ++++++++++++++++++
 .../rest/play/controllers/AdminController.scala | 19 ++++++++++++++++++
 .../controllers/ApplicationController.scala     | 19 ++++++++++++++++++
 .../play/controllers/CounterController.scala    | 19 ++++++++++++++++++
 .../rest/play/controllers/EdgeController.scala  | 19 ++++++++++++++++++
 .../play/controllers/ExperimentController.scala | 19 ++++++++++++++++++
 .../rest/play/controllers/JsonBodyParser.scala  | 19 ++++++++++++++++++
 .../play/controllers/PublishController.scala    | 19 ++++++++++++++++++
 .../rest/play/controllers/QueryController.scala | 19 ++++++++++++++++++
 .../play/controllers/VertexController.scala     | 19 ++++++++++++++++++
 .../rest/play/models/ExactCounterItem.scala     | 19 ++++++++++++++++++
 .../rest/play/models/RankCounterItem.scala      | 19 ++++++++++++++++++
 .../s2graph/rest/play/models/package.scala      | 19 ++++++++++++++++++
 s2rest_play/build.sbt                           | 19 ++++++++++++++++++
 s2rest_play/conf/application.conf               | 18 +++++++++++++++++
 s2rest_play/conf/logger.xml                     | 20 +++++++++++++++++++
 s2rest_play/conf/reference.conf                 | 19 ++++++++++++++++++
 s2rest_play/conf/routes                         | 19 ++++++++++++++++++
 s2rest_play/conf/test.conf                      | 19 ++++++++++++++++++
 .../rest/play/benchmark/BenchmarkCommon.scala   | 19 ++++++++++++++++++
 .../rest/play/benchmark/GraphUtilSpec.scala     | 19 ++++++++++++++++++
 .../rest/play/benchmark/JsonBenchmarkSpec.scala | 19 ++++++++++++++++++
 .../benchmark/OrderingUtilBenchmarkSpec.scala   | 19 ++++++++++++++++++
 .../play/benchmark/SamplingBenchmarkSpec.scala  | 19 ++++++++++++++++++
 .../rest/play/controllers/PostProcessSpec.scala | 19 ++++++++++++++++++
 script/test.sh                                  | 16 +++++++++++++++
 spark/build.sbt                                 | 19 ++++++++++++++++++
 spark/src/main/scala/kafka/KafkaHelper.scala    | 19 ++++++++++++++++++
 .../s2graph/spark/config/S2ConfigFactory.scala  | 19 ++++++++++++++++++
 .../s2graph/spark/spark/HashMapParam.scala      | 21 +++++++++++++++++++-
 .../apache/s2graph/spark/spark/RDDUtil.scala    | 19 ++++++++++++++++++
 .../apache/s2graph/spark/spark/SparkApp.scala   | 19 ++++++++++++++++++
 .../spark/spark/SubscriberListener.scala        | 19 ++++++++++++++++++
 .../apache/s2graph/spark/spark/WithKafka.scala  | 21 +++++++++++++++++++-
 .../streaming/kafka/KafkaRDDFunctions.scala     | 19 ++++++++++++++++++
 .../spark/streaming/kafka/StreamHelper.scala    | 19 ++++++++++++++++++
 .../org/apache/s2graph/spark/SparkAppTest.scala | 19 ++++++++++++++++++
 .../s2graph/spark/TestStreamingSpec.scala       | 19 ++++++++++++++++++
 test.sh                                         | 16 +++++++++++++++
 204 files changed, 3874 insertions(+), 9 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/CHANGES
----------------------------------------------------------------------
diff --git a/CHANGES b/CHANGES
index 8b5fc63..4c16424 100644
--- a/CHANGES
+++ b/CHANGES
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
  Change Log
 
 Release 0.12.1 - unreleased
@@ -72,6 +91,8 @@ Release 0.12.1 - unreleased
     
     S2GRAPH-57: Change package names into org.apahce.s2graph. (Committed by DOYUNG YOON).
 
+    S2GRAPH-4: Update license headers in source codes. (Committed by DOYUNG YOON).
+
   SUB TASKS
 
     S2GRAPH-9: Provide rest server using netty. (Committed by daewon).

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/build.sbt
----------------------------------------------------------------------
diff --git a/build.sbt b/build.sbt
index 5efa284..8571163 100755
--- a/build.sbt
+++ b/build.sbt
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 name := "s2graph"
 
 lazy val commonSettings = Seq(

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/dev_support/graph_mysql/Dockerfile
----------------------------------------------------------------------
diff --git a/dev_support/graph_mysql/Dockerfile b/dev_support/graph_mysql/Dockerfile
index c6849f0..6573665 100644
--- a/dev_support/graph_mysql/Dockerfile
+++ b/dev_support/graph_mysql/Dockerfile
@@ -1,3 +1,22 @@
+#
+# 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.
+#
+
 FROM mysql
 
 MAINTAINER Jaesang Kim <ho...@gmail.com>

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/dev_support/graph_mysql/schema.sql
----------------------------------------------------------------------
diff --git a/dev_support/graph_mysql/schema.sql b/dev_support/graph_mysql/schema.sql
index 2216896..862062b 100644
--- a/dev_support/graph_mysql/schema.sql
+++ b/dev_support/graph_mysql/schema.sql
@@ -1,3 +1,22 @@
+--
+-- 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.
+--
+
 CREATE DATABASE IF NOT EXISTS graph_dev;
 
 CREATE USER 'graph'@'%' IDENTIFIED BY 'graph';

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/loader/build.sbt
----------------------------------------------------------------------
diff --git a/loader/build.sbt b/loader/build.sbt
index 43e1126..2929da8 100644
--- a/loader/build.sbt
+++ b/loader/build.sbt
@@ -1,3 +1,22 @@
+/*
+ * 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 sbtassembly.Plugin.AssemblyKeys._
 
 name := "s2loader"

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/loader/loader.py
----------------------------------------------------------------------
diff --git a/loader/loader.py b/loader/loader.py
index 1345736..1d4dc32 100644
--- a/loader/loader.py
+++ b/loader/loader.py
@@ -1,4 +1,20 @@
 #!/usr/bin/python
+# 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 os, sys, urllib2, urllib
 

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/loader/src/main/resources/log4j.properties
----------------------------------------------------------------------
diff --git a/loader/src/main/resources/log4j.properties b/loader/src/main/resources/log4j.properties
old mode 100755
new mode 100644
index 09e570a..9a4b8ef
--- a/loader/src/main/resources/log4j.properties
+++ b/loader/src/main/resources/log4j.properties
@@ -1,3 +1,20 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+# 
+#   http://www.apache.org/licenses/LICENSE-2.0
+# 
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+
 log4j.rootLogger=${root.logger}
 root.logger=WARN,console
 log4j.appender.console=org.apache.log4j.ConsoleAppender

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/loader/src/main/scala/org/apache/s2graph/loader/subscriber/GraphSubscriber.scala
----------------------------------------------------------------------
diff --git a/loader/src/main/scala/org/apache/s2graph/loader/subscriber/GraphSubscriber.scala b/loader/src/main/scala/org/apache/s2graph/loader/subscriber/GraphSubscriber.scala
index 7838593..9e9fe4c 100644
--- a/loader/src/main/scala/org/apache/s2graph/loader/subscriber/GraphSubscriber.scala
+++ b/loader/src/main/scala/org/apache/s2graph/loader/subscriber/GraphSubscriber.scala
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 package org.apache.s2graph.loader.subscriber
 
 import com.typesafe.config.{Config, ConfigFactory}

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/loader/src/main/scala/org/apache/s2graph/loader/subscriber/TransferToHFile.scala
----------------------------------------------------------------------
diff --git a/loader/src/main/scala/org/apache/s2graph/loader/subscriber/TransferToHFile.scala b/loader/src/main/scala/org/apache/s2graph/loader/subscriber/TransferToHFile.scala
index 60b43ca..06079a7 100644
--- a/loader/src/main/scala/org/apache/s2graph/loader/subscriber/TransferToHFile.scala
+++ b/loader/src/main/scala/org/apache/s2graph/loader/subscriber/TransferToHFile.scala
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 package org.apache.s2graph.loader.subscriber
 
 import org.apache.hadoop.hbase.client.Put

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/loader/src/main/scala/org/apache/s2graph/loader/subscriber/WalLogStat.scala
----------------------------------------------------------------------
diff --git a/loader/src/main/scala/org/apache/s2graph/loader/subscriber/WalLogStat.scala b/loader/src/main/scala/org/apache/s2graph/loader/subscriber/WalLogStat.scala
index 3b54e1c..d47e648 100644
--- a/loader/src/main/scala/org/apache/s2graph/loader/subscriber/WalLogStat.scala
+++ b/loader/src/main/scala/org/apache/s2graph/loader/subscriber/WalLogStat.scala
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 package org.apache.s2graph.loader.subscriber
 
 import kafka.producer.KeyedMessage

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/loader/src/main/scala/org/apache/s2graph/loader/subscriber/WalLogToHDFS.scala
----------------------------------------------------------------------
diff --git a/loader/src/main/scala/org/apache/s2graph/loader/subscriber/WalLogToHDFS.scala b/loader/src/main/scala/org/apache/s2graph/loader/subscriber/WalLogToHDFS.scala
index f51a148..348c81d 100644
--- a/loader/src/main/scala/org/apache/s2graph/loader/subscriber/WalLogToHDFS.scala
+++ b/loader/src/main/scala/org/apache/s2graph/loader/subscriber/WalLogToHDFS.scala
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 package org.apache.s2graph.loader.subscriber
 
 import java.text.SimpleDateFormat

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/loader/src/test/scala/org/apache/s2graph/loader/subscriber/GraphSubscriberTest.scala
----------------------------------------------------------------------
diff --git a/loader/src/test/scala/org/apache/s2graph/loader/subscriber/GraphSubscriberTest.scala b/loader/src/test/scala/org/apache/s2graph/loader/subscriber/GraphSubscriberTest.scala
index 1f93134..64d8198 100644
--- a/loader/src/test/scala/org/apache/s2graph/loader/subscriber/GraphSubscriberTest.scala
+++ b/loader/src/test/scala/org/apache/s2graph/loader/subscriber/GraphSubscriberTest.scala
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 package org.apache.s2graph.loader.subscriber
 
 import org.apache.s2graph.core.Management

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/loader/src/test/scala/org/apache/s2graph/loader/subscriber/TransferToHFileTest.scala
----------------------------------------------------------------------
diff --git a/loader/src/test/scala/org/apache/s2graph/loader/subscriber/TransferToHFileTest.scala b/loader/src/test/scala/org/apache/s2graph/loader/subscriber/TransferToHFileTest.scala
index b0dd80d..0937f4c 100644
--- a/loader/src/test/scala/org/apache/s2graph/loader/subscriber/TransferToHFileTest.scala
+++ b/loader/src/test/scala/org/apache/s2graph/loader/subscriber/TransferToHFileTest.scala
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 package org.apache.s2graph.loader.subscriber
 
 import org.apache.s2graph.core.Management

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/s2core/build.sbt
----------------------------------------------------------------------
diff --git a/s2core/build.sbt b/s2core/build.sbt
index ca40ca7..6774c60 100644
--- a/s2core/build.sbt
+++ b/s2core/build.sbt
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 name := """s2core"""
 
 scalacOptions ++= Seq("-deprecation")

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/s2core/migrate/mysql/schema.sql
----------------------------------------------------------------------
diff --git a/s2core/migrate/mysql/schema.sql b/s2core/migrate/mysql/schema.sql
index 4911348..9ce746c 100644
--- a/s2core/migrate/mysql/schema.sql
+++ b/s2core/migrate/mysql/schema.sql
@@ -1,3 +1,22 @@
+--
+-- 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.
+--
+
 CREATE DATABASE IF NOT EXISTS graph_dev;
 
 CREATE USER 'graph'@'%' IDENTIFIED BY 'graph';

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/s2core/src/main/resources/create_model.hql
----------------------------------------------------------------------
diff --git a/s2core/src/main/resources/create_model.hql b/s2core/src/main/resources/create_model.hql
index 18c870b..831a655 100644
--- a/s2core/src/main/resources/create_model.hql
+++ b/s2core/src/main/resources/create_model.hql
@@ -1 +1,20 @@
+#
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+#
+
 create 's2graph-dev', {NAME => 'e'}, {NAME => 'v'}

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/s2core/src/main/resources/logback.xml
----------------------------------------------------------------------
diff --git a/s2core/src/main/resources/logback.xml b/s2core/src/main/resources/logback.xml
index 18aa2bd..7c2a495 100644
--- a/s2core/src/main/resources/logback.xml
+++ b/s2core/src/main/resources/logback.xml
@@ -1,4 +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.
+-->
+
 <configuration>
     <appender name="STDOUT" class="ch.qos.logback.core.ConsoleAppender">
         <withJansi>true</withJansi>

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/s2core/src/main/resources/reference.conf
----------------------------------------------------------------------
diff --git a/s2core/src/main/resources/reference.conf b/s2core/src/main/resources/reference.conf
index c93d204..1840306 100644
--- a/s2core/src/main/resources/reference.conf
+++ b/s2core/src/main/resources/reference.conf
@@ -1,3 +1,22 @@
+#
+# 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.
+#
+
 # APP PHASE
 phase = dev
 

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/s2core/src/main/scala/org/apache/s2graph/core/Edge.scala
----------------------------------------------------------------------
diff --git a/s2core/src/main/scala/org/apache/s2graph/core/Edge.scala b/s2core/src/main/scala/org/apache/s2graph/core/Edge.scala
index c1a5738..1169ba9 100644
--- a/s2core/src/main/scala/org/apache/s2graph/core/Edge.scala
+++ b/s2core/src/main/scala/org/apache/s2graph/core/Edge.scala
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 package org.apache.s2graph.core
 
 import org.apache.s2graph.core.mysqls.{Label, LabelIndex, LabelMeta}

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/s2core/src/main/scala/org/apache/s2graph/core/ExceptionHandler.scala
----------------------------------------------------------------------
diff --git a/s2core/src/main/scala/org/apache/s2graph/core/ExceptionHandler.scala b/s2core/src/main/scala/org/apache/s2graph/core/ExceptionHandler.scala
index d3177b8..0af9ce5 100644
--- a/s2core/src/main/scala/org/apache/s2graph/core/ExceptionHandler.scala
+++ b/s2core/src/main/scala/org/apache/s2graph/core/ExceptionHandler.scala
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 package org.apache.s2graph.core
 
 import java.util.Properties

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/s2core/src/main/scala/org/apache/s2graph/core/Graph.scala
----------------------------------------------------------------------
diff --git a/s2core/src/main/scala/org/apache/s2graph/core/Graph.scala b/s2core/src/main/scala/org/apache/s2graph/core/Graph.scala
index b2cbd19..ac1d4c1 100644
--- a/s2core/src/main/scala/org/apache/s2graph/core/Graph.scala
+++ b/s2core/src/main/scala/org/apache/s2graph/core/Graph.scala
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 package org.apache.s2graph.core
 
 import java.util

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/s2core/src/main/scala/org/apache/s2graph/core/GraphElement.scala
----------------------------------------------------------------------
diff --git a/s2core/src/main/scala/org/apache/s2graph/core/GraphElement.scala b/s2core/src/main/scala/org/apache/s2graph/core/GraphElement.scala
index 12bb941..1e2f53b 100644
--- a/s2core/src/main/scala/org/apache/s2graph/core/GraphElement.scala
+++ b/s2core/src/main/scala/org/apache/s2graph/core/GraphElement.scala
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 package org.apache.s2graph.core
 
 trait GraphElement {

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/s2core/src/main/scala/org/apache/s2graph/core/GraphExceptions.scala
----------------------------------------------------------------------
diff --git a/s2core/src/main/scala/org/apache/s2graph/core/GraphExceptions.scala b/s2core/src/main/scala/org/apache/s2graph/core/GraphExceptions.scala
index e7d2d76..0898ffa 100644
--- a/s2core/src/main/scala/org/apache/s2graph/core/GraphExceptions.scala
+++ b/s2core/src/main/scala/org/apache/s2graph/core/GraphExceptions.scala
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 package org.apache.s2graph.core
 
 object GraphExceptions {

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/s2core/src/main/scala/org/apache/s2graph/core/GraphUtil.scala
----------------------------------------------------------------------
diff --git a/s2core/src/main/scala/org/apache/s2graph/core/GraphUtil.scala b/s2core/src/main/scala/org/apache/s2graph/core/GraphUtil.scala
index 1a2b916..ebfee7a 100644
--- a/s2core/src/main/scala/org/apache/s2graph/core/GraphUtil.scala
+++ b/s2core/src/main/scala/org/apache/s2graph/core/GraphUtil.scala
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 package org.apache.s2graph.core
 
 import java.util.regex.Pattern

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/s2core/src/main/scala/org/apache/s2graph/core/JSONParser.scala
----------------------------------------------------------------------
diff --git a/s2core/src/main/scala/org/apache/s2graph/core/JSONParser.scala b/s2core/src/main/scala/org/apache/s2graph/core/JSONParser.scala
index 8b9a228..796ba7c 100644
--- a/s2core/src/main/scala/org/apache/s2graph/core/JSONParser.scala
+++ b/s2core/src/main/scala/org/apache/s2graph/core/JSONParser.scala
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 package org.apache.s2graph.core
 
 import org.apache.s2graph.core.types.{InnerVal, InnerValLike}

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/s2core/src/main/scala/org/apache/s2graph/core/Management.scala
----------------------------------------------------------------------
diff --git a/s2core/src/main/scala/org/apache/s2graph/core/Management.scala b/s2core/src/main/scala/org/apache/s2graph/core/Management.scala
index b355757..f9b7431 100644
--- a/s2core/src/main/scala/org/apache/s2graph/core/Management.scala
+++ b/s2core/src/main/scala/org/apache/s2graph/core/Management.scala
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 package org.apache.s2graph.core
 
 import org.apache.s2graph.core.GraphExceptions.{InvalidHTableException, LabelAlreadyExistException, LabelNotExistException}
@@ -365,4 +384,4 @@ class Management(graph: Graph) {
       allIndices, allProps,
       old.consistencyLevel, hTableName, old.hTableTTL, old.schemaVersion, old.isAsync, old.compressionAlgorithm)
   }
-}
\ No newline at end of file
+}

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/s2core/src/main/scala/org/apache/s2graph/core/OrderingUtil.scala
----------------------------------------------------------------------
diff --git a/s2core/src/main/scala/org/apache/s2graph/core/OrderingUtil.scala b/s2core/src/main/scala/org/apache/s2graph/core/OrderingUtil.scala
index c31aa79..0ecbf4e 100644
--- a/s2core/src/main/scala/org/apache/s2graph/core/OrderingUtil.scala
+++ b/s2core/src/main/scala/org/apache/s2graph/core/OrderingUtil.scala
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 package org.apache.s2graph.core
 
 import org.apache.s2graph.core.types.InnerValLike

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/s2core/src/main/scala/org/apache/s2graph/core/PostProcess.scala
----------------------------------------------------------------------
diff --git a/s2core/src/main/scala/org/apache/s2graph/core/PostProcess.scala b/s2core/src/main/scala/org/apache/s2graph/core/PostProcess.scala
index 46b3255..5bfaad7 100644
--- a/s2core/src/main/scala/org/apache/s2graph/core/PostProcess.scala
+++ b/s2core/src/main/scala/org/apache/s2graph/core/PostProcess.scala
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 package org.apache.s2graph.core
 
 import org.apache.s2graph.core.GraphExceptions.BadQueryException

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/s2core/src/main/scala/org/apache/s2graph/core/QueryParam.scala
----------------------------------------------------------------------
diff --git a/s2core/src/main/scala/org/apache/s2graph/core/QueryParam.scala b/s2core/src/main/scala/org/apache/s2graph/core/QueryParam.scala
index 2febadd..4c9175c 100644
--- a/s2core/src/main/scala/org/apache/s2graph/core/QueryParam.scala
+++ b/s2core/src/main/scala/org/apache/s2graph/core/QueryParam.scala
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 package org.apache.s2graph.core
 
 import com.google.common.hash.Hashing

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/s2core/src/main/scala/org/apache/s2graph/core/QueryResult.scala
----------------------------------------------------------------------
diff --git a/s2core/src/main/scala/org/apache/s2graph/core/QueryResult.scala b/s2core/src/main/scala/org/apache/s2graph/core/QueryResult.scala
index 550c4c9..5343659 100644
--- a/s2core/src/main/scala/org/apache/s2graph/core/QueryResult.scala
+++ b/s2core/src/main/scala/org/apache/s2graph/core/QueryResult.scala
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 package org.apache.s2graph.core
 
 import org.apache.s2graph.core.mysqls.LabelMeta

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/s2core/src/main/scala/org/apache/s2graph/core/Vertex.scala
----------------------------------------------------------------------
diff --git a/s2core/src/main/scala/org/apache/s2graph/core/Vertex.scala b/s2core/src/main/scala/org/apache/s2graph/core/Vertex.scala
index f4f40b7..ede1127 100644
--- a/s2core/src/main/scala/org/apache/s2graph/core/Vertex.scala
+++ b/s2core/src/main/scala/org/apache/s2graph/core/Vertex.scala
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 package org.apache.s2graph.core
 
 import org.apache.s2graph.core.mysqls.{ColumnMeta, Service, ServiceColumn}

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/s2core/src/main/scala/org/apache/s2graph/core/mysqls/Bucket.scala
----------------------------------------------------------------------
diff --git a/s2core/src/main/scala/org/apache/s2graph/core/mysqls/Bucket.scala b/s2core/src/main/scala/org/apache/s2graph/core/mysqls/Bucket.scala
index c92c2a2..7626ead 100644
--- a/s2core/src/main/scala/org/apache/s2graph/core/mysqls/Bucket.scala
+++ b/s2core/src/main/scala/org/apache/s2graph/core/mysqls/Bucket.scala
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 package org.apache.s2graph.core.mysqls
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/s2core/src/main/scala/org/apache/s2graph/core/mysqls/ColumnMeta.scala
----------------------------------------------------------------------
diff --git a/s2core/src/main/scala/org/apache/s2graph/core/mysqls/ColumnMeta.scala b/s2core/src/main/scala/org/apache/s2graph/core/mysqls/ColumnMeta.scala
index a726f40..9af6243 100644
--- a/s2core/src/main/scala/org/apache/s2graph/core/mysqls/ColumnMeta.scala
+++ b/s2core/src/main/scala/org/apache/s2graph/core/mysqls/ColumnMeta.scala
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 package org.apache.s2graph.core.mysqls
 
 import play.api.libs.json.Json

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/s2core/src/main/scala/org/apache/s2graph/core/mysqls/Experiment.scala
----------------------------------------------------------------------
diff --git a/s2core/src/main/scala/org/apache/s2graph/core/mysqls/Experiment.scala b/s2core/src/main/scala/org/apache/s2graph/core/mysqls/Experiment.scala
index 3b5fefb..9bd172d 100644
--- a/s2core/src/main/scala/org/apache/s2graph/core/mysqls/Experiment.scala
+++ b/s2core/src/main/scala/org/apache/s2graph/core/mysqls/Experiment.scala
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 package org.apache.s2graph.core.mysqls
 
 import org.apache.s2graph.core.GraphUtil

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/s2core/src/main/scala/org/apache/s2graph/core/mysqls/Label.scala
----------------------------------------------------------------------
diff --git a/s2core/src/main/scala/org/apache/s2graph/core/mysqls/Label.scala b/s2core/src/main/scala/org/apache/s2graph/core/mysqls/Label.scala
index 0958c2c..6e17793 100644
--- a/s2core/src/main/scala/org/apache/s2graph/core/mysqls/Label.scala
+++ b/s2core/src/main/scala/org/apache/s2graph/core/mysqls/Label.scala
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 package org.apache.s2graph.core.mysqls
 
 import org.apache.s2graph.core.GraphExceptions.ModelNotFoundException

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/s2core/src/main/scala/org/apache/s2graph/core/mysqls/LabelIndex.scala
----------------------------------------------------------------------
diff --git a/s2core/src/main/scala/org/apache/s2graph/core/mysqls/LabelIndex.scala b/s2core/src/main/scala/org/apache/s2graph/core/mysqls/LabelIndex.scala
index 31e63c3..d7736bc 100644
--- a/s2core/src/main/scala/org/apache/s2graph/core/mysqls/LabelIndex.scala
+++ b/s2core/src/main/scala/org/apache/s2graph/core/mysqls/LabelIndex.scala
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 package org.apache.s2graph.core.mysqls
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/s2core/src/main/scala/org/apache/s2graph/core/mysqls/LabelMeta.scala
----------------------------------------------------------------------
diff --git a/s2core/src/main/scala/org/apache/s2graph/core/mysqls/LabelMeta.scala b/s2core/src/main/scala/org/apache/s2graph/core/mysqls/LabelMeta.scala
index b641ec5..f2b6bad 100644
--- a/s2core/src/main/scala/org/apache/s2graph/core/mysqls/LabelMeta.scala
+++ b/s2core/src/main/scala/org/apache/s2graph/core/mysqls/LabelMeta.scala
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 package org.apache.s2graph.core.mysqls
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/s2core/src/main/scala/org/apache/s2graph/core/mysqls/Model.scala
----------------------------------------------------------------------
diff --git a/s2core/src/main/scala/org/apache/s2graph/core/mysqls/Model.scala b/s2core/src/main/scala/org/apache/s2graph/core/mysqls/Model.scala
index 700b8d7..7439939 100644
--- a/s2core/src/main/scala/org/apache/s2graph/core/mysqls/Model.scala
+++ b/s2core/src/main/scala/org/apache/s2graph/core/mysqls/Model.scala
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 package org.apache.s2graph.core.mysqls
 
 import java.util.concurrent.Executors

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/s2core/src/main/scala/org/apache/s2graph/core/mysqls/Service.scala
----------------------------------------------------------------------
diff --git a/s2core/src/main/scala/org/apache/s2graph/core/mysqls/Service.scala b/s2core/src/main/scala/org/apache/s2graph/core/mysqls/Service.scala
index 98e1866..3e01014 100644
--- a/s2core/src/main/scala/org/apache/s2graph/core/mysqls/Service.scala
+++ b/s2core/src/main/scala/org/apache/s2graph/core/mysqls/Service.scala
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 package org.apache.s2graph.core.mysqls
 
 import java.util.UUID

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/s2core/src/main/scala/org/apache/s2graph/core/mysqls/ServiceColumn.scala
----------------------------------------------------------------------
diff --git a/s2core/src/main/scala/org/apache/s2graph/core/mysqls/ServiceColumn.scala b/s2core/src/main/scala/org/apache/s2graph/core/mysqls/ServiceColumn.scala
index 6d33fe2..e86aa36 100644
--- a/s2core/src/main/scala/org/apache/s2graph/core/mysqls/ServiceColumn.scala
+++ b/s2core/src/main/scala/org/apache/s2graph/core/mysqls/ServiceColumn.scala
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 package org.apache.s2graph.core.mysqls
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/s2core/src/main/scala/org/apache/s2graph/core/parsers/WhereParser.scala
----------------------------------------------------------------------
diff --git a/s2core/src/main/scala/org/apache/s2graph/core/parsers/WhereParser.scala b/s2core/src/main/scala/org/apache/s2graph/core/parsers/WhereParser.scala
index d5a3687..f48bec6 100644
--- a/s2core/src/main/scala/org/apache/s2graph/core/parsers/WhereParser.scala
+++ b/s2core/src/main/scala/org/apache/s2graph/core/parsers/WhereParser.scala
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 package org.apache.s2graph.core.parsers
 
 import org.apache.s2graph.core.GraphExceptions.WhereParserException

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/s2core/src/main/scala/org/apache/s2graph/core/rest/RequestParser.scala
----------------------------------------------------------------------
diff --git a/s2core/src/main/scala/org/apache/s2graph/core/rest/RequestParser.scala b/s2core/src/main/scala/org/apache/s2graph/core/rest/RequestParser.scala
index b0af967..f8671a7 100644
--- a/s2core/src/main/scala/org/apache/s2graph/core/rest/RequestParser.scala
+++ b/s2core/src/main/scala/org/apache/s2graph/core/rest/RequestParser.scala
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 package org.apache.s2graph.core.rest
 
 import java.util.concurrent.{Callable, TimeUnit}

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/s2core/src/main/scala/org/apache/s2graph/core/rest/RestHandler.scala
----------------------------------------------------------------------
diff --git a/s2core/src/main/scala/org/apache/s2graph/core/rest/RestHandler.scala b/s2core/src/main/scala/org/apache/s2graph/core/rest/RestHandler.scala
index a48bc7c..55b3e79 100644
--- a/s2core/src/main/scala/org/apache/s2graph/core/rest/RestHandler.scala
+++ b/s2core/src/main/scala/org/apache/s2graph/core/rest/RestHandler.scala
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 package org.apache.s2graph.core.rest
 
 import java.net.URL

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/s2core/src/main/scala/org/apache/s2graph/core/storage/Deserializable.scala
----------------------------------------------------------------------
diff --git a/s2core/src/main/scala/org/apache/s2graph/core/storage/Deserializable.scala b/s2core/src/main/scala/org/apache/s2graph/core/storage/Deserializable.scala
index 12e9547..d82c507 100644
--- a/s2core/src/main/scala/org/apache/s2graph/core/storage/Deserializable.scala
+++ b/s2core/src/main/scala/org/apache/s2graph/core/storage/Deserializable.scala
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 package org.apache.s2graph.core.storage
 
 import org.apache.hadoop.hbase.util.Bytes
@@ -21,4 +40,4 @@ trait Deserializable[E] extends StorageDeserializable[E] {
     val rowLen = srcIdLen + 4 + 1
     (srcVertexId, labelWithDir, labelIdxSeq, isInverted, rowLen)
   }
-}
\ No newline at end of file
+}

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/s2core/src/main/scala/org/apache/s2graph/core/storage/SKeyValue.scala
----------------------------------------------------------------------
diff --git a/s2core/src/main/scala/org/apache/s2graph/core/storage/SKeyValue.scala b/s2core/src/main/scala/org/apache/s2graph/core/storage/SKeyValue.scala
index 5310248..b690307 100644
--- a/s2core/src/main/scala/org/apache/s2graph/core/storage/SKeyValue.scala
+++ b/s2core/src/main/scala/org/apache/s2graph/core/storage/SKeyValue.scala
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 package org.apache.s2graph.core.storage
 
 import org.apache.hadoop.hbase.util.Bytes

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/s2core/src/main/scala/org/apache/s2graph/core/storage/Serializable.scala
----------------------------------------------------------------------
diff --git a/s2core/src/main/scala/org/apache/s2graph/core/storage/Serializable.scala b/s2core/src/main/scala/org/apache/s2graph/core/storage/Serializable.scala
index 08a3f73..bd5e3d3 100644
--- a/s2core/src/main/scala/org/apache/s2graph/core/storage/Serializable.scala
+++ b/s2core/src/main/scala/org/apache/s2graph/core/storage/Serializable.scala
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 package org.apache.s2graph.core.storage
 
 object Serializable {

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/s2core/src/main/scala/org/apache/s2graph/core/storage/Storage.scala
----------------------------------------------------------------------
diff --git a/s2core/src/main/scala/org/apache/s2graph/core/storage/Storage.scala b/s2core/src/main/scala/org/apache/s2graph/core/storage/Storage.scala
index 34e9fcb..a4af95a 100644
--- a/s2core/src/main/scala/org/apache/s2graph/core/storage/Storage.scala
+++ b/s2core/src/main/scala/org/apache/s2graph/core/storage/Storage.scala
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 package org.apache.s2graph.core.storage
 
 import com.typesafe.config.Config

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/s2core/src/main/scala/org/apache/s2graph/core/storage/StorageDeserializable.scala
----------------------------------------------------------------------
diff --git a/s2core/src/main/scala/org/apache/s2graph/core/storage/StorageDeserializable.scala b/s2core/src/main/scala/org/apache/s2graph/core/storage/StorageDeserializable.scala
index 74cd308..69926fa 100644
--- a/s2core/src/main/scala/org/apache/s2graph/core/storage/StorageDeserializable.scala
+++ b/s2core/src/main/scala/org/apache/s2graph/core/storage/StorageDeserializable.scala
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 package org.apache.s2graph.core.storage
 
 import org.apache.hadoop.hbase.util.Bytes

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/s2core/src/main/scala/org/apache/s2graph/core/storage/StorageSerializable.scala
----------------------------------------------------------------------
diff --git a/s2core/src/main/scala/org/apache/s2graph/core/storage/StorageSerializable.scala b/s2core/src/main/scala/org/apache/s2graph/core/storage/StorageSerializable.scala
index 46ce539..b6435e4 100644
--- a/s2core/src/main/scala/org/apache/s2graph/core/storage/StorageSerializable.scala
+++ b/s2core/src/main/scala/org/apache/s2graph/core/storage/StorageSerializable.scala
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 package org.apache.s2graph.core.storage
 
 import org.apache.hadoop.hbase.util.Bytes

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/s2core/src/main/scala/org/apache/s2graph/core/storage/hbase/AsynchbaseStorage.scala
----------------------------------------------------------------------
diff --git a/s2core/src/main/scala/org/apache/s2graph/core/storage/hbase/AsynchbaseStorage.scala b/s2core/src/main/scala/org/apache/s2graph/core/storage/hbase/AsynchbaseStorage.scala
index 2560c9d..66a1be4 100644
--- a/s2core/src/main/scala/org/apache/s2graph/core/storage/hbase/AsynchbaseStorage.scala
+++ b/s2core/src/main/scala/org/apache/s2graph/core/storage/hbase/AsynchbaseStorage.scala
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 package org.apache.s2graph.core.storage.hbase
 
 import java.util

http://git-wip-us.apache.org/repos/asf/incubator-s2graph/blob/92aaa518/s2core/src/main/scala/org/apache/s2graph/core/storage/serde/indexedge/tall/IndexEdgeDeserializable.scala
----------------------------------------------------------------------
diff --git a/s2core/src/main/scala/org/apache/s2graph/core/storage/serde/indexedge/tall/IndexEdgeDeserializable.scala b/s2core/src/main/scala/org/apache/s2graph/core/storage/serde/indexedge/tall/IndexEdgeDeserializable.scala
index 143f02d..f233940 100644
--- a/s2core/src/main/scala/org/apache/s2graph/core/storage/serde/indexedge/tall/IndexEdgeDeserializable.scala
+++ b/s2core/src/main/scala/org/apache/s2graph/core/storage/serde/indexedge/tall/IndexEdgeDeserializable.scala
@@ -1,3 +1,22 @@
+/*
+ * 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.
+ */
+
 package org.apache.s2graph.core.storage.serde.indexedge.tall
 
 import org.apache.hadoop.hbase.util.Bytes