You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@reef.apache.org by ju...@apache.org on 2014/11/01 00:38:05 UTC

[27/31] Updated LICENSE and LICENSE headers

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/context/ServiceConfiguration.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/context/ServiceConfiguration.java b/reef-common/src/main/java/org/apache/reef/driver/context/ServiceConfiguration.java
index 6505c13..93a50d6 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/context/ServiceConfiguration.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/context/ServiceConfiguration.java
@@ -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.
  */
 package org.apache.reef.driver.context;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/evaluator/AllocatedEvaluator.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/evaluator/AllocatedEvaluator.java b/reef-common/src/main/java/org/apache/reef/driver/evaluator/AllocatedEvaluator.java
index 2ccffa4..198bf00 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/evaluator/AllocatedEvaluator.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/evaluator/AllocatedEvaluator.java
@@ -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.
  */
 package org.apache.reef.driver.evaluator;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/evaluator/CompletedEvaluator.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/evaluator/CompletedEvaluator.java b/reef-common/src/main/java/org/apache/reef/driver/evaluator/CompletedEvaluator.java
index 15fa6bc..70e34a5 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/evaluator/CompletedEvaluator.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/evaluator/CompletedEvaluator.java
@@ -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.
  */
 package org.apache.reef.driver.evaluator;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/evaluator/EvaluatorDescriptor.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/evaluator/EvaluatorDescriptor.java b/reef-common/src/main/java/org/apache/reef/driver/evaluator/EvaluatorDescriptor.java
index d3f4ccc..55a0ddd 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/evaluator/EvaluatorDescriptor.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/evaluator/EvaluatorDescriptor.java
@@ -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.
  */
 package org.apache.reef.driver.evaluator;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/evaluator/EvaluatorRequest.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/evaluator/EvaluatorRequest.java b/reef-common/src/main/java/org/apache/reef/driver/evaluator/EvaluatorRequest.java
index 1b52994..7094a42 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/evaluator/EvaluatorRequest.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/evaluator/EvaluatorRequest.java
@@ -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.
  */
 package org.apache.reef.driver.evaluator;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/evaluator/EvaluatorRequestor.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/evaluator/EvaluatorRequestor.java b/reef-common/src/main/java/org/apache/reef/driver/evaluator/EvaluatorRequestor.java
index 91fb51c..6999298 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/evaluator/EvaluatorRequestor.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/evaluator/EvaluatorRequestor.java
@@ -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.
  */
 package org.apache.reef.driver.evaluator;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/evaluator/EvaluatorType.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/evaluator/EvaluatorType.java b/reef-common/src/main/java/org/apache/reef/driver/evaluator/EvaluatorType.java
index 10c6fcc..6c27db8 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/evaluator/EvaluatorType.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/evaluator/EvaluatorType.java
@@ -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.
  */
 package org.apache.reef.driver.evaluator;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/evaluator/FailedEvaluator.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/evaluator/FailedEvaluator.java b/reef-common/src/main/java/org/apache/reef/driver/evaluator/FailedEvaluator.java
index 07d03e9..c173457 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/evaluator/FailedEvaluator.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/evaluator/FailedEvaluator.java
@@ -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.
  */
 package org.apache.reef.driver.evaluator;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/package-info.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/package-info.java b/reef-common/src/main/java/org/apache/reef/driver/package-info.java
index 35b7edd..c03ab68 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/package-info.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/package-info.java
@@ -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.
  */
 /**
  * Driver APIs for REEF in terms of Rx.

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/parameters/ClientCloseHandlers.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/parameters/ClientCloseHandlers.java b/reef-common/src/main/java/org/apache/reef/driver/parameters/ClientCloseHandlers.java
index 5b53b33..b2d45f9 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/parameters/ClientCloseHandlers.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/parameters/ClientCloseHandlers.java
@@ -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.
  */
 package org.apache.reef.driver.parameters;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/parameters/ClientCloseWithMessageHandlers.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/parameters/ClientCloseWithMessageHandlers.java b/reef-common/src/main/java/org/apache/reef/driver/parameters/ClientCloseWithMessageHandlers.java
index a36097e..708301d 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/parameters/ClientCloseWithMessageHandlers.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/parameters/ClientCloseWithMessageHandlers.java
@@ -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.
  */
 package org.apache.reef.driver.parameters;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/parameters/ClientMessageHandlers.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/parameters/ClientMessageHandlers.java b/reef-common/src/main/java/org/apache/reef/driver/parameters/ClientMessageHandlers.java
index c31edee..82b61de 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/parameters/ClientMessageHandlers.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/parameters/ClientMessageHandlers.java
@@ -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.
  */
 package org.apache.reef.driver.parameters;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/parameters/ContextActiveHandlers.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/parameters/ContextActiveHandlers.java b/reef-common/src/main/java/org/apache/reef/driver/parameters/ContextActiveHandlers.java
index 3a39b89..724d7a8 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/parameters/ContextActiveHandlers.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/parameters/ContextActiveHandlers.java
@@ -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.
  */
 package org.apache.reef.driver.parameters;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/parameters/ContextClosedHandlers.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/parameters/ContextClosedHandlers.java b/reef-common/src/main/java/org/apache/reef/driver/parameters/ContextClosedHandlers.java
index e2142c5..e5b282a 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/parameters/ContextClosedHandlers.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/parameters/ContextClosedHandlers.java
@@ -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.
  */
 package org.apache.reef.driver.parameters;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/parameters/ContextFailedHandlers.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/parameters/ContextFailedHandlers.java b/reef-common/src/main/java/org/apache/reef/driver/parameters/ContextFailedHandlers.java
index b0e558f..1ded6f9 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/parameters/ContextFailedHandlers.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/parameters/ContextFailedHandlers.java
@@ -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.
  */
 package org.apache.reef.driver.parameters;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/parameters/ContextMessageHandlers.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/parameters/ContextMessageHandlers.java b/reef-common/src/main/java/org/apache/reef/driver/parameters/ContextMessageHandlers.java
index e0482df..dc3ddd2 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/parameters/ContextMessageHandlers.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/parameters/ContextMessageHandlers.java
@@ -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.
  */
 package org.apache.reef.driver.parameters;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverIdentifier.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverIdentifier.java b/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverIdentifier.java
index 0201227..484aa67 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverIdentifier.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverIdentifier.java
@@ -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.
  */
 package org.apache.reef.driver.parameters;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverIdleSources.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverIdleSources.java b/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverIdleSources.java
index 35901f6..403513d 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverIdleSources.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverIdleSources.java
@@ -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.
  */
 package org.apache.reef.driver.parameters;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverJobSubmissionDirectory.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverJobSubmissionDirectory.java b/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverJobSubmissionDirectory.java
index 328e675..8201960 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverJobSubmissionDirectory.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverJobSubmissionDirectory.java
@@ -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.
  */
 package org.apache.reef.driver.parameters;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverLocalFiles.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverLocalFiles.java b/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverLocalFiles.java
index 18741a9..4ecfc54 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverLocalFiles.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverLocalFiles.java
@@ -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.
  */
 package org.apache.reef.driver.parameters;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverLocalLibraries.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverLocalLibraries.java b/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverLocalLibraries.java
index bf3f247..10eb996 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverLocalLibraries.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverLocalLibraries.java
@@ -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.
  */
 package org.apache.reef.driver.parameters;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverMemory.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverMemory.java b/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverMemory.java
index 69aba49..8df693c 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverMemory.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverMemory.java
@@ -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.
  */
 package org.apache.reef.driver.parameters;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverRestartCompletedHandlers.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverRestartCompletedHandlers.java b/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverRestartCompletedHandlers.java
index acb0904..341f9e4 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverRestartCompletedHandlers.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverRestartCompletedHandlers.java
@@ -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.
  */
 package org.apache.reef.driver.parameters;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverRestartContextActiveHandlers.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverRestartContextActiveHandlers.java b/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverRestartContextActiveHandlers.java
index ef84292..e06e5d9 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverRestartContextActiveHandlers.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverRestartContextActiveHandlers.java
@@ -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.
  */
 package org.apache.reef.driver.parameters;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverRestartHandler.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverRestartHandler.java b/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverRestartHandler.java
index 900aaf9..b67974c 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverRestartHandler.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverRestartHandler.java
@@ -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.
  */
 package org.apache.reef.driver.parameters;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverRestartTaskRunningHandlers.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverRestartTaskRunningHandlers.java b/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverRestartTaskRunningHandlers.java
index e34cbd0..3fd1732 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverRestartTaskRunningHandlers.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverRestartTaskRunningHandlers.java
@@ -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.
  */
 package org.apache.reef.driver.parameters;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverStartHandler.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverStartHandler.java b/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverStartHandler.java
index 1caf2a9..eeb1afa 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverStartHandler.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/parameters/DriverStartHandler.java
@@ -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.
  */
 package org.apache.reef.driver.parameters;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/parameters/EvaluatorAllocatedHandlers.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/parameters/EvaluatorAllocatedHandlers.java b/reef-common/src/main/java/org/apache/reef/driver/parameters/EvaluatorAllocatedHandlers.java
index 45d5841..7ac4c80 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/parameters/EvaluatorAllocatedHandlers.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/parameters/EvaluatorAllocatedHandlers.java
@@ -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.
  */
 package org.apache.reef.driver.parameters;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/parameters/EvaluatorCompletedHandlers.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/parameters/EvaluatorCompletedHandlers.java b/reef-common/src/main/java/org/apache/reef/driver/parameters/EvaluatorCompletedHandlers.java
index 7e3210d..893460f 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/parameters/EvaluatorCompletedHandlers.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/parameters/EvaluatorCompletedHandlers.java
@@ -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.
  */
 package org.apache.reef.driver.parameters;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/parameters/EvaluatorDispatcherThreads.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/parameters/EvaluatorDispatcherThreads.java b/reef-common/src/main/java/org/apache/reef/driver/parameters/EvaluatorDispatcherThreads.java
index af8f518..731461a 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/parameters/EvaluatorDispatcherThreads.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/parameters/EvaluatorDispatcherThreads.java
@@ -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.
  */
 package org.apache.reef.driver.parameters;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/parameters/EvaluatorFailedHandlers.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/parameters/EvaluatorFailedHandlers.java b/reef-common/src/main/java/org/apache/reef/driver/parameters/EvaluatorFailedHandlers.java
index aae9a31..774248c 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/parameters/EvaluatorFailedHandlers.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/parameters/EvaluatorFailedHandlers.java
@@ -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.
  */
 package org.apache.reef.driver.parameters;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/parameters/JobGlobalFiles.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/parameters/JobGlobalFiles.java b/reef-common/src/main/java/org/apache/reef/driver/parameters/JobGlobalFiles.java
index efb7c37..1cd188f 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/parameters/JobGlobalFiles.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/parameters/JobGlobalFiles.java
@@ -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.
  */
 package org.apache.reef.driver.parameters;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/parameters/JobGlobalLibraries.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/parameters/JobGlobalLibraries.java b/reef-common/src/main/java/org/apache/reef/driver/parameters/JobGlobalLibraries.java
index 1c9ad2c..e2db582 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/parameters/JobGlobalLibraries.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/parameters/JobGlobalLibraries.java
@@ -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.
  */
 package org.apache.reef.driver.parameters;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceContextActiveHandlers.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceContextActiveHandlers.java b/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceContextActiveHandlers.java
index 1121c48..716b7b9 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceContextActiveHandlers.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceContextActiveHandlers.java
@@ -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.
  */
 package org.apache.reef.driver.parameters;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceContextClosedHandlers.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceContextClosedHandlers.java b/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceContextClosedHandlers.java
index f2b5dd1..21c4c7f 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceContextClosedHandlers.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceContextClosedHandlers.java
@@ -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.
  */
 package org.apache.reef.driver.parameters;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceContextFailedHandlers.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceContextFailedHandlers.java b/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceContextFailedHandlers.java
index 898cb6c..b7acf0c 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceContextFailedHandlers.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceContextFailedHandlers.java
@@ -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.
  */
 package org.apache.reef.driver.parameters;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceContextMessageHandlers.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceContextMessageHandlers.java b/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceContextMessageHandlers.java
index 7f97671..aa26a78 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceContextMessageHandlers.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceContextMessageHandlers.java
@@ -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.
  */
 package org.apache.reef.driver.parameters;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceDriverRestartCompletedHandlers.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceDriverRestartCompletedHandlers.java b/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceDriverRestartCompletedHandlers.java
index a2bd452..106783a 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceDriverRestartCompletedHandlers.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceDriverRestartCompletedHandlers.java
@@ -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.
  */
 package org.apache.reef.driver.parameters;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceDriverRestartContextActiveHandlers.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceDriverRestartContextActiveHandlers.java b/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceDriverRestartContextActiveHandlers.java
index 501d077..eb7debf 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceDriverRestartContextActiveHandlers.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceDriverRestartContextActiveHandlers.java
@@ -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.
  */
 package org.apache.reef.driver.parameters;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceDriverRestartTaskRunningHandlers.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceDriverRestartTaskRunningHandlers.java b/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceDriverRestartTaskRunningHandlers.java
index 5b54dd6..4f0b6b6 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceDriverRestartTaskRunningHandlers.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceDriverRestartTaskRunningHandlers.java
@@ -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.
  */
 package org.apache.reef.driver.parameters;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceEvaluatorAllocatedHandlers.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceEvaluatorAllocatedHandlers.java b/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceEvaluatorAllocatedHandlers.java
index 0b70ee4..17748b9 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceEvaluatorAllocatedHandlers.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceEvaluatorAllocatedHandlers.java
@@ -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.
  */
 package org.apache.reef.driver.parameters;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/d3bdc7ae/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceEvaluatorCompletedHandlers.java
----------------------------------------------------------------------
diff --git a/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceEvaluatorCompletedHandlers.java b/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceEvaluatorCompletedHandlers.java
index 3295c76..929af2a 100644
--- a/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceEvaluatorCompletedHandlers.java
+++ b/reef-common/src/main/java/org/apache/reef/driver/parameters/ServiceEvaluatorCompletedHandlers.java
@@ -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.
  */
 package org.apache.reef.driver.parameters;