Return-Path: X-Original-To: apmail-beam-commits-archive@minotaur.apache.org Delivered-To: apmail-beam-commits-archive@minotaur.apache.org Received: from mail.apache.org (hermes.apache.org [140.211.11.3]) by minotaur.apache.org (Postfix) with SMTP id 049E019E3D for ; Wed, 30 Mar 2016 23:35:00 +0000 (UTC) Received: (qmail 24522 invoked by uid 500); 30 Mar 2016 23:34:57 -0000 Delivered-To: apmail-beam-commits-archive@beam.apache.org Received: (qmail 24452 invoked by uid 500); 30 Mar 2016 23:34:57 -0000 Mailing-List: contact commits-help@beam.incubator.apache.org; run by ezmlm Precedence: bulk List-Help: List-Unsubscribe: List-Post: List-Id: Reply-To: dev@beam.incubator.apache.org Delivered-To: mailing list commits@beam.incubator.apache.org Received: (qmail 24361 invoked by uid 99); 30 Mar 2016 23:34:57 -0000 Received: from pnap-us-west-generic-nat.apache.org (HELO spamd1-us-west.apache.org) (209.188.14.142) by apache.org (qpsmtpd/0.29) with ESMTP; Wed, 30 Mar 2016 23:34:57 +0000 Received: from localhost (localhost [127.0.0.1]) by spamd1-us-west.apache.org (ASF Mail Server at spamd1-us-west.apache.org) with ESMTP id 1956CC17D9 for ; Wed, 30 Mar 2016 23:34:57 +0000 (UTC) X-Virus-Scanned: Debian amavisd-new at spamd1-us-west.apache.org X-Spam-Flag: NO X-Spam-Score: -4.216 X-Spam-Level: X-Spam-Status: No, score=-4.216 tagged_above=-999 required=6.31 tests=[KAM_ASCII_DIVIDERS=0.8, KAM_LAZY_DOMAIN_SECURITY=1, RCVD_IN_DNSWL_HI=-5, RCVD_IN_MSPIKE_H3=-0.01, RCVD_IN_MSPIKE_WL=-0.01, RP_MATCHES_RCVD=-0.996] autolearn=disabled Received: from mx2-lw-us.apache.org ([10.40.0.8]) by localhost (spamd1-us-west.apache.org [10.40.0.7]) (amavisd-new, port 10024) with ESMTP id gui0z-4T12JR for ; Wed, 30 Mar 2016 23:34:52 +0000 (UTC) Received: from mail.apache.org (hermes.apache.org [140.211.11.3]) by mx2-lw-us.apache.org (ASF Mail Server at mx2-lw-us.apache.org) with SMTP id C190E5FB3F for ; Wed, 30 Mar 2016 23:34:45 +0000 (UTC) Received: (qmail 22266 invoked by uid 99); 30 Mar 2016 23:34:44 -0000 Received: from git1-us-west.apache.org (HELO git1-us-west.apache.org) (140.211.11.23) by apache.org (qpsmtpd/0.29) with ESMTP; Wed, 30 Mar 2016 23:34:44 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id F2DFFE97B6; Wed, 30 Mar 2016 23:34:43 +0000 (UTC) Content-Type: text/plain; charset="us-ascii" MIME-Version: 1.0 Content-Transfer-Encoding: 7bit From: dhalperi@apache.org To: commits@beam.incubator.apache.org Date: Wed, 30 Mar 2016 23:34:57 -0000 Message-Id: <996202d58bcc44a69a8676c8c4288f4d@git.apache.org> In-Reply-To: <3d4e8b8c2a16477bb6d14bf3b697408d@git.apache.org> References: <3d4e8b8c2a16477bb6d14bf3b697408d@git.apache.org> X-Mailer: ASF-Git Admin Mailer Subject: [15/23] incubator-beam git commit: Update LICENSE header across all files http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/testing/TestDataflowPipelineOptions.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/testing/TestDataflowPipelineOptions.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/testing/TestDataflowPipelineOptions.java index 1afb691..2f920a6 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/testing/TestDataflowPipelineOptions.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/testing/TestDataflowPipelineOptions.java @@ -1,19 +1,20 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.testing; import com.google.cloud.dataflow.sdk.options.BlockingDataflowPipelineOptions; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/testing/TestDataflowPipelineRunner.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/testing/TestDataflowPipelineRunner.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/testing/TestDataflowPipelineRunner.java index 9fff070..065d808 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/testing/TestDataflowPipelineRunner.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/testing/TestDataflowPipelineRunner.java @@ -1,19 +1,20 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.testing; import com.google.api.services.dataflow.model.JobMessage; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/testing/TestPipeline.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/testing/TestPipeline.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/testing/TestPipeline.java index a05a778..a942868 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/testing/TestPipeline.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/testing/TestPipeline.java @@ -1,19 +1,20 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.testing; import com.google.cloud.dataflow.sdk.Pipeline; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/testing/WindowFnTestUtils.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/testing/WindowFnTestUtils.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/testing/WindowFnTestUtils.java index dc0baf5..2a30e86 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/testing/WindowFnTestUtils.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/testing/WindowFnTestUtils.java @@ -1,19 +1,20 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.testing; import static org.hamcrest.Matchers.greaterThan; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/testing/package-info.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/testing/package-info.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/testing/package-info.java index d6f075d..d178b44 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/testing/package-info.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/testing/package-info.java @@ -1,19 +1,20 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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. */ - /** * Defines utilities for unit testing Dataflow pipelines. The tests for the {@code PTransform}s and * examples included the Dataflow SDK provide examples of using these utilities. http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Aggregator.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Aggregator.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Aggregator.java index 7e56dda..3cb6aab 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Aggregator.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Aggregator.java @@ -1,19 +1,20 @@ -/******************************************************************************* - * Copyright (C) 2015 Google Inc. +/* + * 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. - ******************************************************************************/ - + * 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 com.google.cloud.dataflow.sdk.transforms; import com.google.cloud.dataflow.sdk.transforms.Combine.CombineFn; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/AggregatorRetriever.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/AggregatorRetriever.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/AggregatorRetriever.java index 4bbea85..ceabb13 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/AggregatorRetriever.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/AggregatorRetriever.java @@ -1,19 +1,20 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.transforms; import java.util.Collection; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/AppliedPTransform.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/AppliedPTransform.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/AppliedPTransform.java index 7b3d87d..8f050cc 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/AppliedPTransform.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/AppliedPTransform.java @@ -1,19 +1,20 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.transforms; import com.google.cloud.dataflow.sdk.values.PInput; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/ApproximateQuantiles.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/ApproximateQuantiles.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/ApproximateQuantiles.java index 57dd510..6ed1c0f 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/ApproximateQuantiles.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/ApproximateQuantiles.java @@ -1,19 +1,20 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.transforms; import com.google.cloud.dataflow.sdk.coders.BigEndianIntegerCoder; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/ApproximateUnique.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/ApproximateUnique.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/ApproximateUnique.java index 3c936a2..d8e925f 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/ApproximateUnique.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/ApproximateUnique.java @@ -1,19 +1,20 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.transforms; import com.google.cloud.dataflow.sdk.coders.Coder; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Combine.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Combine.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Combine.java index b8d20e3..c6d2f58 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Combine.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Combine.java @@ -1,17 +1,19 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.transforms; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/CombineFnBase.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/CombineFnBase.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/CombineFnBase.java index a0b06cf..0b097d6 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/CombineFnBase.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/CombineFnBase.java @@ -1,17 +1,19 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.transforms; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/CombineFns.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/CombineFns.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/CombineFns.java index 656c010..7af5292 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/CombineFns.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/CombineFns.java @@ -1,17 +1,19 @@ /* - * Copyright (C) 2016 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.transforms; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/CombineWithContext.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/CombineWithContext.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/CombineWithContext.java index fdf56e3..db21b9e 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/CombineWithContext.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/CombineWithContext.java @@ -1,17 +1,19 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.transforms; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Count.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Count.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Count.java index ffa11d1..d5350bc 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Count.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Count.java @@ -1,19 +1,20 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.transforms; import com.google.cloud.dataflow.sdk.transforms.Combine.CombineFn; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Create.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Create.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Create.java index a74e5bf..4bccdc1 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Create.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Create.java @@ -1,19 +1,20 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.transforms; import com.google.cloud.dataflow.sdk.Pipeline; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/DoFn.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/DoFn.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/DoFn.java index 5ba9992..b5ba983 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/DoFn.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/DoFn.java @@ -1,19 +1,20 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.transforms; import static com.google.common.base.Preconditions.checkArgument; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/DoFnReflector.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/DoFnReflector.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/DoFnReflector.java index 1c46541..56af699 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/DoFnReflector.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/DoFnReflector.java @@ -1,19 +1,20 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.transforms; import com.google.cloud.dataflow.sdk.options.PipelineOptions; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/DoFnTester.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/DoFnTester.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/DoFnTester.java index 5447664..1535e8e 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/DoFnTester.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/DoFnTester.java @@ -1,19 +1,20 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.transforms; import com.google.cloud.dataflow.sdk.annotations.Experimental; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/DoFnWithContext.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/DoFnWithContext.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/DoFnWithContext.java index 4f131ad..a6d06c9 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/DoFnWithContext.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/DoFnWithContext.java @@ -1,19 +1,20 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.transforms; import static com.google.common.base.Preconditions.checkArgument; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Filter.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Filter.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Filter.java index 9e123a1..30893b6 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Filter.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Filter.java @@ -1,19 +1,20 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.transforms; import com.google.cloud.dataflow.sdk.coders.Coder; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/FlatMapElements.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/FlatMapElements.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/FlatMapElements.java index fbaad5b..d5bbf2b 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/FlatMapElements.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/FlatMapElements.java @@ -1,19 +1,20 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.transforms; import com.google.cloud.dataflow.sdk.values.PCollection; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Flatten.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Flatten.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Flatten.java index de6add0..3db56d8 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Flatten.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Flatten.java @@ -1,19 +1,20 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.transforms; import com.google.cloud.dataflow.sdk.coders.CannotProvideCoderException; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/GroupByKey.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/GroupByKey.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/GroupByKey.java index 8fde3e0..ec6306d 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/GroupByKey.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/GroupByKey.java @@ -1,19 +1,20 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.transforms; import static com.google.cloud.dataflow.sdk.util.CoderUtils.encodeToByteArray; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/IntraBundleParallelization.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/IntraBundleParallelization.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/IntraBundleParallelization.java index 39d2dc8..0a6787c 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/IntraBundleParallelization.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/IntraBundleParallelization.java @@ -1,19 +1,20 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.transforms; import com.google.cloud.dataflow.sdk.options.GcsOptions; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Keys.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Keys.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Keys.java index 370d43d..2430336 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Keys.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Keys.java @@ -1,19 +1,20 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.transforms; import com.google.cloud.dataflow.sdk.values.KV; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/KvSwap.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/KvSwap.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/KvSwap.java index 5a9cc87..5209f53 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/KvSwap.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/KvSwap.java @@ -1,19 +1,20 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.transforms; import com.google.cloud.dataflow.sdk.values.KV; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/MapElements.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/MapElements.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/MapElements.java index 8997050..c483e97 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/MapElements.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/MapElements.java @@ -1,19 +1,20 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.transforms; import com.google.cloud.dataflow.sdk.values.PCollection; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Max.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Max.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Max.java index 8678e4f..f19af3b 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Max.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Max.java @@ -1,19 +1,20 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.transforms; import com.google.cloud.dataflow.sdk.transforms.Combine.BinaryCombineFn; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Mean.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Mean.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Mean.java index 7dccfb6..74b4a8c 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Mean.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Mean.java @@ -1,19 +1,20 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.transforms; import com.google.cloud.dataflow.sdk.coders.AtomicCoder; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Min.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Min.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Min.java index 47ab3a0..26212f6 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Min.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Min.java @@ -1,19 +1,20 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.transforms; import com.google.cloud.dataflow.sdk.transforms.Combine.BinaryCombineFn; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/PTransform.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/PTransform.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/PTransform.java index d4496b8..8ef28da 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/PTransform.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/PTransform.java @@ -1,19 +1,20 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.transforms; import com.google.cloud.dataflow.sdk.Pipeline; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/ParDo.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/ParDo.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/ParDo.java index c77ac44..89c9023 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/ParDo.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/ParDo.java @@ -1,19 +1,20 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.transforms; import com.google.cloud.dataflow.sdk.Pipeline; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Partition.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Partition.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Partition.java index bbbccbc..60e1d49 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Partition.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Partition.java @@ -1,19 +1,20 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.transforms; import com.google.cloud.dataflow.sdk.coders.Coder; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/RemoveDuplicates.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/RemoveDuplicates.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/RemoveDuplicates.java index 8913138..c9738a3 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/RemoveDuplicates.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/RemoveDuplicates.java @@ -1,19 +1,20 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.transforms; import com.google.cloud.dataflow.sdk.values.KV; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Sample.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Sample.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Sample.java index 13de40b..83c7f2e 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Sample.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Sample.java @@ -1,19 +1,20 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.transforms; import com.google.cloud.dataflow.sdk.coders.BigEndianIntegerCoder; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/SerializableComparator.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/SerializableComparator.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/SerializableComparator.java index 7d41917..52cdaa0 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/SerializableComparator.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/SerializableComparator.java @@ -1,19 +1,20 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.transforms; import java.io.Serializable; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/SerializableFunction.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/SerializableFunction.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/SerializableFunction.java index 81bf3d4..d1da82d 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/SerializableFunction.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/SerializableFunction.java @@ -1,19 +1,20 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.transforms; import java.io.Serializable; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/SimpleFunction.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/SimpleFunction.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/SimpleFunction.java index ef6fd81..bb8ea4c 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/SimpleFunction.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/SimpleFunction.java @@ -1,19 +1,20 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.transforms; import com.google.cloud.dataflow.sdk.values.TypeDescriptor; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Sum.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Sum.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Sum.java index 5b30475..7144aa3 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Sum.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Sum.java @@ -1,19 +1,20 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.transforms; import com.google.cloud.dataflow.sdk.util.common.Counter; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Top.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Top.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Top.java index 98fe53c..b81c152 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Top.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Top.java @@ -1,19 +1,20 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.transforms; import com.google.cloud.dataflow.sdk.coders.Coder; http://git-wip-us.apache.org/repos/asf/incubator-beam/blob/d59c8012/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Values.java ---------------------------------------------------------------------- diff --git a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Values.java b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Values.java index d84bc77..3fc69ca 100644 --- a/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Values.java +++ b/sdks/java/core/src/main/java/com/google/cloud/dataflow/sdk/transforms/Values.java @@ -1,19 +1,20 @@ /* - * Copyright (C) 2015 Google Inc. + * 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. + * 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 com.google.cloud.dataflow.sdk.transforms; import com.google.cloud.dataflow.sdk.values.KV;