You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@reef.apache.org by ch...@apache.org on 2014/12/30 06:02:14 UTC

incubator-reef git commit: [REEF-26]: Fix the license headers of files

Repository: incubator-reef
Updated Branches:
  refs/heads/master b3ea4548a -> ce092b219


[REEF-26]: Fix the license headers of files

JIRA: [REEF-26](https://issues.apache.org/jira/browse/REEF-26)

Pull Request: Closes #41

Author:    Byung-Gon Chun <bg...@apache.org>


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

Branch: refs/heads/master
Commit: ce092b219c3691da94687d981b0ef901a7f2a691
Parents: b3ea454
Author: Byung-Gon Chun <bg...@apache.org>
Authored: Mon Dec 29 14:08:04 2014 +0900
Committer: chobrian <ch...@apache.org>
Committed: Tue Dec 30 13:56:02 2014 +0900

----------------------------------------------------------------------
 bin/runreef.ps1                                 | 28 +++++++++++---------
 bin/runreef.psm1                                | 24 ++++++++++-------
 bin/runtests.ps1                                | 28 +++++++++++---------
 .../ClrHandler/Properties/AssemblyInfo.cs       | 16 -----------
 .../ClrHandler/interface/IInteropReturnInfo.cs  | 16 -----------
 .../CSharp/ClrHandler/interface/ILogger.cs      | 18 +------------
 .../org/apache/reef/util/EnvironmentUtils.java  |  1 -
 reef-io/src/main/avro/nameservice.avsc          | 27 ++++++++++---------
 reef-io/src/main/proto/ns_protocol.proto        | 25 +++++++++--------
 reef-tang/tang/src/main/avro/configuration.avsc | 25 +++++++++--------
 .../evaluatorfailure/EvaluatorFailureTest.java  | 15 -----------
 .../wake/src/main/proto/RemoteProtocol.proto    | 27 ++++++++++---------
 reef-wake/wake/src/test/proto/TestEvent1.proto  | 27 ++++++++++---------
 .../wake/src/test/proto/TestProtocol.proto      | 27 ++++++++++---------
 14 files changed, 135 insertions(+), 169 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/ce092b21/bin/runreef.ps1
----------------------------------------------------------------------
diff --git a/bin/runreef.ps1 b/bin/runreef.ps1
index 104ffc4..f334e0e 100644
--- a/bin/runreef.ps1
+++ b/bin/runreef.ps1
@@ -7,18 +7,22 @@ that JAVA_HOME and HADOOP_HOME are set.
 #>
 
 <#
-Copyright (C) 2014 Microsoft Corporation
-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.
+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.
 #>
 param
   (

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/ce092b21/bin/runreef.psm1
----------------------------------------------------------------------
diff --git a/bin/runreef.psm1 b/bin/runreef.psm1
index 3f61da5..c074759 100644
--- a/bin/runreef.psm1
+++ b/bin/runreef.psm1
@@ -4,18 +4,22 @@ Helper unctions to run REEF applications
 #>
 
 <#
-Copyright (C) 2014 Microsoft Corporation
-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
+Licensed to the Apache Software Foundation (ASF) under one
+or more contributor license agreements.  See the NOTICE file
+distributed with this work for additional information
+regarding copyright ownership.  The ASF licenses this file
+to you under the Apache License, Version 2.0 (the
+"License"); you may not use this file except in compliance
+with the License.  You may obtain a copy of the License at
 
-        http://www.apache.org/licenses/LICENSE-2.0
+  http://www.apache.org/licenses/LICENSE-2.0
 
-Unless required by applicable law or agreed to in writing, software
-distributed under the License is distributed on an "AS IS" BASIS,
-WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-See the License for the specific language governing permissions and
-limitations under the License.
+Unless required by applicable law or agreed to in writing,
+software distributed under the License is distributed on an
+"AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+KIND, either express or implied.  See the License for the
+specific language governing permissions and limitations
+under the License.
 #>
 
 function Get-YARN-Classpath {

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/ce092b21/bin/runtests.ps1
----------------------------------------------------------------------
diff --git a/bin/runtests.ps1 b/bin/runtests.ps1
index 9a313cb..3b376a0 100644
--- a/bin/runtests.ps1
+++ b/bin/runtests.ps1
@@ -7,18 +7,22 @@ This assumes that JAVA_HOME and HADOOP_HOME are set.
 #>
 
 <#
-Copyright (C) 2014 Microsoft Corporation
-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.
+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.
 #>
 param
   (

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/ce092b21/reef-bridge-project/reef-bridge-clr/src/main/CSharp/CSharp/ClrHandler/Properties/AssemblyInfo.cs
----------------------------------------------------------------------
diff --git a/reef-bridge-project/reef-bridge-clr/src/main/CSharp/CSharp/ClrHandler/Properties/AssemblyInfo.cs b/reef-bridge-project/reef-bridge-clr/src/main/CSharp/CSharp/ClrHandler/Properties/AssemblyInfo.cs
index 819b995..5812e03 100644
--- a/reef-bridge-project/reef-bridge-clr/src/main/CSharp/CSharp/ClrHandler/Properties/AssemblyInfo.cs
+++ b/reef-bridge-project/reef-bridge-clr/src/main/CSharp/CSharp/ClrHandler/Properties/AssemblyInfo.cs
@@ -16,22 +16,6 @@
  * specific language governing permissions and limitations
  * under the License.
  */
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * 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.
- */
-
 using System.Reflection;
 using System.Runtime.InteropServices;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/ce092b21/reef-bridge-project/reef-bridge-clr/src/main/CSharp/CSharp/ClrHandler/interface/IInteropReturnInfo.cs
----------------------------------------------------------------------
diff --git a/reef-bridge-project/reef-bridge-clr/src/main/CSharp/CSharp/ClrHandler/interface/IInteropReturnInfo.cs b/reef-bridge-project/reef-bridge-clr/src/main/CSharp/CSharp/ClrHandler/interface/IInteropReturnInfo.cs
index 7620092..b3b930a 100644
--- a/reef-bridge-project/reef-bridge-clr/src/main/CSharp/CSharp/ClrHandler/interface/IInteropReturnInfo.cs
+++ b/reef-bridge-project/reef-bridge-clr/src/main/CSharp/CSharp/ClrHandler/interface/IInteropReturnInfo.cs
@@ -16,22 +16,6 @@
  * specific language governing permissions and limitations
  * under the License.
  */
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * 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.
- */
-
 using System;
 
 namespace Microsoft.Reef.Interop

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/ce092b21/reef-bridge-project/reef-bridge-clr/src/main/CSharp/CSharp/ClrHandler/interface/ILogger.cs
----------------------------------------------------------------------
diff --git a/reef-bridge-project/reef-bridge-clr/src/main/CSharp/CSharp/ClrHandler/interface/ILogger.cs b/reef-bridge-project/reef-bridge-clr/src/main/CSharp/CSharp/ClrHandler/interface/ILogger.cs
index 7f200e7..4a7f9b2 100644
--- a/reef-bridge-project/reef-bridge-clr/src/main/CSharp/CSharp/ClrHandler/interface/ILogger.cs
+++ b/reef-bridge-project/reef-bridge-clr/src/main/CSharp/CSharp/ClrHandler/interface/ILogger.cs
@@ -16,22 +16,6 @@
  * specific language governing permissions and limitations
  * under the License.
  */
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * 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.
- */
-
 using System;
 
 namespace Microsoft.Reef.Interop
@@ -50,4 +34,4 @@ namespace Microsoft.Reef.Interop
     {
         void Log(TraceLevel traceLevel, String message);
     }
-}
\ No newline at end of file
+}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/ce092b21/reef-common/src/main/java/org/apache/reef/util/EnvironmentUtils.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/util/EnvironmentUtils.java b/reef-common/src/main/java/org/apache/reef/util/EnvironmentUtils.java
index d61422e..9d19d35 100644
--- a/reef-common/src/main/java/org/apache/reef/util/EnvironmentUtils.java
+++ b/reef-common/src/main/java/org/apache/reef/util/EnvironmentUtils.java
@@ -104,7 +104,6 @@ public final class EnvironmentUtils {
    * @param <P>
    * @return
    * @deprecated in 0.2 this really should be in Tang.
-   * See <a href="https://github.com/Microsoft-CISL/TANG/issues/164">Tang #164</a> for details.
    */
   @Deprecated
   public static <P extends Param> ConfigurationModule addAll(

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/ce092b21/reef-io/src/main/avro/nameservice.avsc
----------------------------------------------------------------------
diff --git a/reef-io/src/main/avro/nameservice.avsc b/reef-io/src/main/avro/nameservice.avsc
index 2b5bb24..9a10478 100644
--- a/reef-io/src/main/avro/nameservice.avsc
+++ b/reef-io/src/main/avro/nameservice.avsc
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014 Microsoft Corporation
+ * 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
  *
- * 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
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
  [
 {
@@ -58,4 +61,4 @@
 	   {"name":"id","type":"string"}
     ]
 }
-]
\ No newline at end of file
+]

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/ce092b21/reef-io/src/main/proto/ns_protocol.proto
----------------------------------------------------------------------
diff --git a/reef-io/src/main/proto/ns_protocol.proto b/reef-io/src/main/proto/ns_protocol.proto
index 6693327..1a9db1e 100644
--- a/reef-io/src/main/proto/ns_protocol.proto
+++ b/reef-io/src/main/proto/ns_protocol.proto
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2013 Microsoft Corporation
+ * 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
  *
- * 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
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 option java_package = "org.apache.reef.io.network.proto";
 option java_outer_classname = "ReefNetworkServiceProtos";

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/ce092b21/reef-tang/tang/src/main/avro/configuration.avsc
----------------------------------------------------------------------
diff --git a/reef-tang/tang/src/main/avro/configuration.avsc b/reef-tang/tang/src/main/avro/configuration.avsc
index 79d73a1..4a7b4f9 100644
--- a/reef-tang/tang/src/main/avro/configuration.avsc
+++ b/reef-tang/tang/src/main/avro/configuration.avsc
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2014 Microsoft Corporation
+ * 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
  *
- * 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
  *
- *         http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
  [
 {

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/ce092b21/reef-tests/src/test/java/org/apache/reef/tests/evaluatorfailure/EvaluatorFailureTest.java
----------------------------------------------------------------------
diff --git a/reef-tests/src/test/java/org/apache/reef/tests/evaluatorfailure/EvaluatorFailureTest.java b/reef-tests/src/test/java/org/apache/reef/tests/evaluatorfailure/EvaluatorFailureTest.java
index 38cdabc..5aa1893 100644
--- a/reef-tests/src/test/java/org/apache/reef/tests/evaluatorfailure/EvaluatorFailureTest.java
+++ b/reef-tests/src/test/java/org/apache/reef/tests/evaluatorfailure/EvaluatorFailureTest.java
@@ -17,21 +17,6 @@
  * under the License.
  */
 package org.apache.reef.tests.evaluatorfailure;
-/**
- * Copyright (C) 2014 Microsoft Corporation
- *
- * 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.
- */
 
 import org.apache.reef.client.DriverConfiguration;
 import org.apache.reef.client.DriverLauncher;

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/ce092b21/reef-wake/wake/src/main/proto/RemoteProtocol.proto
----------------------------------------------------------------------
diff --git a/reef-wake/wake/src/main/proto/RemoteProtocol.proto b/reef-wake/wake/src/main/proto/RemoteProtocol.proto
index 4c679d0..588feae 100644
--- a/reef-wake/wake/src/main/proto/RemoteProtocol.proto
+++ b/reef-wake/wake/src/main/proto/RemoteProtocol.proto
@@ -1,17 +1,20 @@
-/*
- * Copyright 2013 Microsoft.
+/**
+ * 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
  *
- * 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
  *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 option java_package = "org.apache.reef.wake.remote.proto";
 option java_outer_classname = "WakeRemoteProtos";

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/ce092b21/reef-wake/wake/src/test/proto/TestEvent1.proto
----------------------------------------------------------------------
diff --git a/reef-wake/wake/src/test/proto/TestEvent1.proto b/reef-wake/wake/src/test/proto/TestEvent1.proto
index 42e1d72..6c536ae 100644
--- a/reef-wake/wake/src/test/proto/TestEvent1.proto
+++ b/reef-wake/wake/src/test/proto/TestEvent1.proto
@@ -1,17 +1,20 @@
-/*
- * Copyright 2013 Microsoft.
+/**
+ * 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
  *
- * 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
  *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 option java_package = "org.apache.reef.wake.test.remote";
 option java_outer_classname = "TestRemote";

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/ce092b21/reef-wake/wake/src/test/proto/TestProtocol.proto
----------------------------------------------------------------------
diff --git a/reef-wake/wake/src/test/proto/TestProtocol.proto b/reef-wake/wake/src/test/proto/TestProtocol.proto
index 6c171d4..b375cb7 100644
--- a/reef-wake/wake/src/test/proto/TestProtocol.proto
+++ b/reef-wake/wake/src/test/proto/TestProtocol.proto
@@ -1,17 +1,20 @@
-/*
- * Copyright 2013 Microsoft.
+/**
+ * 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
  *
- * 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
  *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 option java_package = "org.apache.reef.wake.test.proto";
 option java_outer_classname = "TestProtos";