You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@crunch.apache.org by jw...@apache.org on 2013/05/07 13:57:48 UTC

[1/2] git commit: Split up aggregated Comparators wrapper class into individual compilation units under the sort package

Updated Branches:
  refs/heads/master 669519f42 -> 0251bc604


Split up aggregated Comparators wrapper class into individual compilation units under the sort package


Project: http://git-wip-us.apache.org/repos/asf/crunch/repo
Commit: http://git-wip-us.apache.org/repos/asf/crunch/commit/7bb1dcf8
Tree: http://git-wip-us.apache.org/repos/asf/crunch/tree/7bb1dcf8
Diff: http://git-wip-us.apache.org/repos/asf/crunch/diff/7bb1dcf8

Branch: refs/heads/master
Commit: 7bb1dcf86c7e4f2b304fc559d7acd24979ccb056
Parents: 669519f
Author: Josh Wills <jw...@apache.org>
Authored: Mon May 6 20:49:43 2013 -0700
Committer: Josh Wills <jw...@apache.org>
Committed: Mon May 6 20:49:43 2013 -0700

----------------------------------------------------------------------
 .../src/main/java/org/apache/crunch/lib/Sort.java  |    4 +-
 .../org/apache/crunch/lib/sort/Comparators.java    |  187 ---------------
 .../crunch/lib/sort/ReverseAvroComparator.java     |   46 ++++
 .../crunch/lib/sort/ReverseWritableComparator.java |   47 ++++
 .../crunch/lib/sort/TupleWritableComparator.java   |  127 ++++++++++
 5 files changed, 223 insertions(+), 188 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/crunch/blob/7bb1dcf8/crunch-core/src/main/java/org/apache/crunch/lib/Sort.java
----------------------------------------------------------------------
diff --git a/crunch-core/src/main/java/org/apache/crunch/lib/Sort.java b/crunch-core/src/main/java/org/apache/crunch/lib/Sort.java
index 23bcaee..60c1b85 100644
--- a/crunch-core/src/main/java/org/apache/crunch/lib/Sort.java
+++ b/crunch-core/src/main/java/org/apache/crunch/lib/Sort.java
@@ -17,7 +17,6 @@
  */
 package org.apache.crunch.lib;
 
-import static org.apache.crunch.lib.sort.Comparators.*;
 import static org.apache.crunch.lib.sort.SortFns.*;
 
 import org.apache.avro.Schema;
@@ -34,6 +33,9 @@ import org.apache.crunch.Tuple3;
 import org.apache.crunch.Tuple4;
 import org.apache.crunch.TupleN;
 import org.apache.crunch.lib.sort.TotalOrderPartitioner;
+import org.apache.crunch.lib.sort.ReverseAvroComparator;
+import org.apache.crunch.lib.sort.ReverseWritableComparator;
+import org.apache.crunch.lib.sort.TupleWritableComparator;
 import org.apache.crunch.materialize.MaterializableIterable;
 import org.apache.crunch.types.PTableType;
 import org.apache.crunch.types.PType;

http://git-wip-us.apache.org/repos/asf/crunch/blob/7bb1dcf8/crunch-core/src/main/java/org/apache/crunch/lib/sort/Comparators.java
----------------------------------------------------------------------
diff --git a/crunch-core/src/main/java/org/apache/crunch/lib/sort/Comparators.java b/crunch-core/src/main/java/org/apache/crunch/lib/sort/Comparators.java
deleted file mode 100644
index ae7f49a..0000000
--- a/crunch-core/src/main/java/org/apache/crunch/lib/sort/Comparators.java
+++ /dev/null
@@ -1,187 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.crunch.lib.sort;
-
-import java.util.Arrays;
-
-import org.apache.avro.Schema;
-import org.apache.avro.io.BinaryData;
-import org.apache.avro.mapred.AvroKey;
-import org.apache.avro.reflect.ReflectData;
-import org.apache.crunch.lib.Sort.ColumnOrder;
-import org.apache.crunch.lib.Sort.Order;
-import org.apache.crunch.types.writable.TupleWritable;
-import org.apache.hadoop.conf.Configurable;
-import org.apache.hadoop.conf.Configuration;
-import org.apache.hadoop.conf.Configured;
-import org.apache.hadoop.io.RawComparator;
-import org.apache.hadoop.io.Writable;
-import org.apache.hadoop.io.WritableComparable;
-import org.apache.hadoop.io.WritableComparator;
-import org.apache.hadoop.mapred.JobConf;
-
-import com.google.common.base.Function;
-import com.google.common.base.Joiner;
-import com.google.common.collect.Iterables;
-
-/**
- * A collection of {@code RawComparator<T>} implementations that are used by Crunch's {@code Sort} library.
- */
-public class Comparators {
-  
-  public static class ReverseWritableComparator<T> extends Configured implements RawComparator<T> {
-
-    private RawComparator<T> comparator;
-
-    @SuppressWarnings("unchecked")
-    @Override
-    public void setConf(Configuration conf) {
-      super.setConf(conf);
-      if (conf != null) {
-        JobConf jobConf = new JobConf(conf);
-        comparator = WritableComparator.get(jobConf.getMapOutputKeyClass().asSubclass(WritableComparable.class));
-      }
-    }
-
-    @Override
-    public int compare(byte[] arg0, int arg1, int arg2, byte[] arg3, int arg4, int arg5) {
-      return -comparator.compare(arg0, arg1, arg2, arg3, arg4, arg5);
-    }
-
-    @Override
-    public int compare(T o1, T o2) {
-      return -comparator.compare(o1, o2);
-    }
-  }
-
-  public static class ReverseAvroComparator<T> extends Configured implements RawComparator<AvroKey<T>> {
-
-    private Schema schema;
-
-    @Override
-    public void setConf(Configuration conf) {
-      super.setConf(conf);
-      if (conf != null) {
-        schema = (new Schema.Parser()).parse(conf.get("crunch.schema"));
-      }
-    }
-
-    @Override
-    public int compare(AvroKey<T> o1, AvroKey<T> o2) {
-      return -ReflectData.get().compare(o1.datum(), o2.datum(), schema);
-    }
-
-    @Override
-    public int compare(byte[] arg0, int arg1, int arg2, byte[] arg3, int arg4, int arg5) {
-      return -BinaryData.compare(arg0, arg1, arg2, arg3, arg4, arg5, schema);
-    }
-  }
-
-  public static class TupleWritableComparator extends WritableComparator implements Configurable {
-
-    private static final String CRUNCH_ORDERING_PROPERTY = "crunch.ordering";
-
-    private Configuration conf;
-    private ColumnOrder[] columnOrders;
-
-    public TupleWritableComparator() {
-      super(TupleWritable.class, true);
-    }
-
-    public static void configureOrdering(Configuration conf, Order... orders) {
-      conf.set(CRUNCH_ORDERING_PROPERTY,
-          Joiner.on(",").join(Iterables.transform(Arrays.asList(orders), new Function<Order, String>() {
-            @Override
-            public String apply(Order o) {
-              return o.name();
-            }
-          })));
-    }
-
-    public static void configureOrdering(Configuration conf, ColumnOrder... columnOrders) {
-      conf.set(CRUNCH_ORDERING_PROPERTY,
-          Joiner.on(",").join(Iterables.transform(Arrays.asList(columnOrders), new Function<ColumnOrder, String>() {
-            @Override
-            public String apply(ColumnOrder o) {
-              return o.column() + ";" + o.order().name();
-            }
-          })));
-    }
-
-    @Override
-    public int compare(WritableComparable a, WritableComparable b) {
-      TupleWritable ta = (TupleWritable) a;
-      TupleWritable tb = (TupleWritable) b;
-      for (int index = 0; index < columnOrders.length; index++) {
-        int order = 1;
-        if (columnOrders[index].order() == Order.ASCENDING) {
-          order = 1;
-        } else if (columnOrders[index].order() == Order.DESCENDING) {
-          order = -1;
-        } else { // ignore
-          continue;
-        }
-        if (!ta.has(index) && !tb.has(index)) {
-          continue;
-        } else if (ta.has(index) && !tb.has(index)) {
-          return order;
-        } else if (!ta.has(index) && tb.has(index)) {
-          return -order;
-        } else {
-          Writable v1 = ta.get(index);
-          Writable v2 = tb.get(index);
-          if (v1 != v2 && (v1 != null && !v1.equals(v2))) {
-            if (v1 instanceof WritableComparable && v2 instanceof WritableComparable) {
-              int cmp = ((WritableComparable) v1).compareTo((WritableComparable) v2);
-              if (cmp != 0) {
-                return order * cmp;
-              }
-            } else {
-              int cmp = v1.hashCode() - v2.hashCode();
-              if (cmp != 0) {
-                return order * cmp;
-              }
-            }
-          }
-        }
-      }
-      return 0; // ordering using specified cols found no differences
-    }
-
-    @Override
-    public Configuration getConf() {
-      return conf;
-    }
-
-    @Override
-    public void setConf(Configuration conf) {
-      this.conf = conf;
-      if (conf != null) {
-        String ordering = conf.get(CRUNCH_ORDERING_PROPERTY);
-        String[] columnOrderNames = ordering.split(",");
-        columnOrders = new ColumnOrder[columnOrderNames.length];
-        for (int i = 0; i < columnOrders.length; i++) {
-          String[] split = columnOrderNames[i].split(";");
-          int column = Integer.parseInt(split[0]);
-          Order order = Order.valueOf(split[1]);
-          columnOrders[i] = ColumnOrder.by(column, order);
-        }
-      }
-    }
-  }
-}

http://git-wip-us.apache.org/repos/asf/crunch/blob/7bb1dcf8/crunch-core/src/main/java/org/apache/crunch/lib/sort/ReverseAvroComparator.java
----------------------------------------------------------------------
diff --git a/crunch-core/src/main/java/org/apache/crunch/lib/sort/ReverseAvroComparator.java b/crunch-core/src/main/java/org/apache/crunch/lib/sort/ReverseAvroComparator.java
new file mode 100644
index 0000000..d83071b
--- /dev/null
+++ b/crunch-core/src/main/java/org/apache/crunch/lib/sort/ReverseAvroComparator.java
@@ -0,0 +1,46 @@
+/**
+ * Copyright (c) 2013, Cloudera, Inc. All Rights Reserved.
+ *
+ * Cloudera, Inc. licenses this file to you under the Apache License,
+ * Version 2.0 (the "License"). You may not use this file except in
+ * compliance with the License. You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This software 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.crunch.lib.sort;
+
+import org.apache.avro.Schema;
+import org.apache.avro.io.BinaryData;
+import org.apache.avro.mapred.AvroKey;
+import org.apache.avro.reflect.ReflectData;
+import org.apache.hadoop.conf.Configuration;
+import org.apache.hadoop.conf.Configured;
+import org.apache.hadoop.io.RawComparator;
+
+public class ReverseAvroComparator<T> extends Configured implements RawComparator<AvroKey<T>> {
+
+  private Schema schema;
+
+  @Override
+  public void setConf(Configuration conf) {
+    super.setConf(conf);
+    if (conf != null) {
+      schema = (new Schema.Parser()).parse(conf.get("crunch.schema"));
+    }
+  }
+
+  @Override
+  public int compare(AvroKey<T> o1, AvroKey<T> o2) {
+    return -ReflectData.get().compare(o1.datum(), o2.datum(), schema);
+  }
+
+  @Override
+  public int compare(byte[] arg0, int arg1, int arg2, byte[] arg3, int arg4, int arg5) {
+    return -BinaryData.compare(arg0, arg1, arg2, arg3, arg4, arg5, schema);
+  }
+}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/crunch/blob/7bb1dcf8/crunch-core/src/main/java/org/apache/crunch/lib/sort/ReverseWritableComparator.java
----------------------------------------------------------------------
diff --git a/crunch-core/src/main/java/org/apache/crunch/lib/sort/ReverseWritableComparator.java b/crunch-core/src/main/java/org/apache/crunch/lib/sort/ReverseWritableComparator.java
new file mode 100644
index 0000000..c2d0c46
--- /dev/null
+++ b/crunch-core/src/main/java/org/apache/crunch/lib/sort/ReverseWritableComparator.java
@@ -0,0 +1,47 @@
+/**
+ * Copyright (c) 2013, Cloudera, Inc. All Rights Reserved.
+ *
+ * Cloudera, Inc. licenses this file to you under the Apache License,
+ * Version 2.0 (the "License"). You may not use this file except in
+ * compliance with the License. You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * This software 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.crunch.lib.sort;
+
+import org.apache.hadoop.conf.Configuration;
+import org.apache.hadoop.conf.Configured;
+import org.apache.hadoop.io.RawComparator;
+import org.apache.hadoop.io.WritableComparable;
+import org.apache.hadoop.io.WritableComparator;
+import org.apache.hadoop.mapred.JobConf;
+
+public class ReverseWritableComparator<T> extends Configured implements RawComparator<T> {
+
+  private RawComparator<T> comparator;
+
+  @SuppressWarnings("unchecked")
+  @Override
+  public void setConf(Configuration conf) {
+    super.setConf(conf);
+    if (conf != null) {
+      JobConf jobConf = new JobConf(conf);
+      comparator = WritableComparator.get(jobConf.getMapOutputKeyClass().asSubclass(WritableComparable.class));
+    }
+  }
+
+  @Override
+  public int compare(byte[] arg0, int arg1, int arg2, byte[] arg3, int arg4, int arg5) {
+    return -comparator.compare(arg0, arg1, arg2, arg3, arg4, arg5);
+  }
+
+  @Override
+  public int compare(T o1, T o2) {
+    return -comparator.compare(o1, o2);
+  }
+}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/crunch/blob/7bb1dcf8/crunch-core/src/main/java/org/apache/crunch/lib/sort/TupleWritableComparator.java
----------------------------------------------------------------------
diff --git a/crunch-core/src/main/java/org/apache/crunch/lib/sort/TupleWritableComparator.java b/crunch-core/src/main/java/org/apache/crunch/lib/sort/TupleWritableComparator.java
new file mode 100644
index 0000000..07ee5b5
--- /dev/null
+++ b/crunch-core/src/main/java/org/apache/crunch/lib/sort/TupleWritableComparator.java
@@ -0,0 +1,127 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.crunch.lib.sort;
+
+import java.util.Arrays;
+
+import org.apache.crunch.lib.Sort.ColumnOrder;
+import org.apache.crunch.lib.Sort.Order;
+import org.apache.crunch.types.writable.TupleWritable;
+import org.apache.hadoop.conf.Configurable;
+import org.apache.hadoop.conf.Configuration;
+import org.apache.hadoop.io.Writable;
+import org.apache.hadoop.io.WritableComparable;
+import org.apache.hadoop.io.WritableComparator;
+
+import com.google.common.base.Function;
+import com.google.common.base.Joiner;
+import com.google.common.collect.Iterables;
+
+public class TupleWritableComparator extends WritableComparator implements Configurable {
+
+  private static final String CRUNCH_ORDERING_PROPERTY = "crunch.ordering";
+
+  private Configuration conf;
+  private ColumnOrder[] columnOrders;
+
+  public TupleWritableComparator() {
+    super(TupleWritable.class, true);
+  }
+
+  public static void configureOrdering(Configuration conf, Order... orders) {
+    conf.set(CRUNCH_ORDERING_PROPERTY,
+        Joiner.on(",").join(Iterables.transform(Arrays.asList(orders), new Function<Order, String>() {
+          @Override
+          public String apply(Order o) {
+            return o.name();
+          }
+        })));
+  }
+
+  public static void configureOrdering(Configuration conf, ColumnOrder... columnOrders) {
+    conf.set(CRUNCH_ORDERING_PROPERTY,
+        Joiner.on(",").join(Iterables.transform(Arrays.asList(columnOrders), new Function<ColumnOrder, String>() {
+          @Override
+          public String apply(ColumnOrder o) {
+            return o.column() + ";" + o.order().name();
+          }
+        })));
+  }
+
+  @Override
+  public int compare(WritableComparable a, WritableComparable b) {
+    TupleWritable ta = (TupleWritable) a;
+    TupleWritable tb = (TupleWritable) b;
+    for (int index = 0; index < columnOrders.length; index++) {
+      int order = 1;
+      if (columnOrders[index].order() == Order.ASCENDING) {
+        order = 1;
+      } else if (columnOrders[index].order() == Order.DESCENDING) {
+        order = -1;
+      } else { // ignore
+        continue;
+      }
+      if (!ta.has(index) && !tb.has(index)) {
+        continue;
+      } else if (ta.has(index) && !tb.has(index)) {
+        return order;
+      } else if (!ta.has(index) && tb.has(index)) {
+        return -order;
+      } else {
+        Writable v1 = ta.get(index);
+        Writable v2 = tb.get(index);
+        if (v1 != v2 && (v1 != null && !v1.equals(v2))) {
+          if (v1 instanceof WritableComparable && v2 instanceof WritableComparable) {
+            int cmp = ((WritableComparable) v1).compareTo((WritableComparable) v2);
+            if (cmp != 0) {
+              return order * cmp;
+            }
+          } else {
+            int cmp = v1.hashCode() - v2.hashCode();
+            if (cmp != 0) {
+              return order * cmp;
+            }
+          }
+        }
+      }
+    }
+    return 0; // ordering using specified cols found no differences
+  }
+
+  @Override
+  public Configuration getConf() {
+    return conf;
+  }
+
+  @Override
+  public void setConf(Configuration conf) {
+    this.conf = conf;
+    if (conf != null) {
+      String ordering = conf.get(CRUNCH_ORDERING_PROPERTY);
+      String[] columnOrderNames = ordering.split(",");
+      columnOrders = new ColumnOrder[columnOrderNames.length];
+      for (int i = 0; i < columnOrders.length; i++) {
+        String[] split = columnOrderNames[i].split(";");
+        int column = Integer.parseInt(split[0]);
+        Order order = Order.valueOf(split[1]);
+        columnOrders[i] = ColumnOrder.by(column, order);
+      }
+    }
+  }
+}
+


Re: [2/2] git commit: Fix license headers

Posted by Josh Wills <jw...@cloudera.com>.
On Tue, May 7, 2013 at 10:19 AM, Matthias Friedrich <ma...@mafr.de> wrote:

> On Tuesday, 2013-05-07, Josh Wills wrote:
> > Close it. We may need to fix the trevni thing too.
> >
> > Why doesn't rat pick it up?
>
> Because it's a valid license, it doesn't discriminate ;-)
>

LOL-- okay :) I get burned by this every time I setup a new Eclipse project
and forget to change my default header.


>
> Regards,
>   Matthias
>



-- 
Director of Data Science
Cloudera <http://www.cloudera.com>
Twitter: @josh_wills <http://twitter.com/josh_wills>

Re: [2/2] git commit: Fix license headers

Posted by Matthias Friedrich <ma...@mafr.de>.
On Tuesday, 2013-05-07, Josh Wills wrote:
> Close it. We may need to fix the trevni thing too.
> 
> Why doesn't rat pick it up?

Because it's a valid license, it doesn't discriminate ;-)

Regards,
  Matthias

Re: [2/2] git commit: Fix license headers

Posted by Josh Wills <jo...@gmail.com>.
Close it. We may need to fix the trevni thing too.

Why doesn't rat pick it up?
On May 7, 2013 12:26 PM, "Matthias Friedrich" <ma...@mafr.de> wrote:

> Hmm, it seems there's still one with Cloudera license header left:
>
>
> crunch-hbase/src/main/java/org/apache/crunch/io/hbase/TableOutputFormat.java
>
> What do we do release-wise?
>
> Regards,
>   Matthias
>
> On Tuesday, 2013-05-07, jwills@apache.org wrote:
> > Fix license headers
> >
> >
> > Project: http://git-wip-us.apache.org/repos/asf/crunch/repo
> > Commit: http://git-wip-us.apache.org/repos/asf/crunch/commit/0251bc60
> > Tree: http://git-wip-us.apache.org/repos/asf/crunch/tree/0251bc60
> > Diff: http://git-wip-us.apache.org/repos/asf/crunch/diff/0251bc60
> >
> > Branch: refs/heads/master
> > Commit: 0251bc604b67a1d433f25e432271a67239fdafd1
> > Parents: 7bb1dcf
> > Author: Josh Wills <jw...@apache.org>
> > Authored: Mon May 6 21:39:26 2013 -0700
> > Committer: Josh Wills <jw...@apache.org>
> > Committed: Mon May 6 21:39:26 2013 -0700
> >
> > ----------------------------------------------------------------------
> >  .../crunch/lib/sort/ReverseAvroComparator.java     |   21 ++++++++------
> >  .../crunch/lib/sort/ReverseWritableComparator.java |   21 ++++++++------
> >  2 files changed, 24 insertions(+), 18 deletions(-)
> > ----------------------------------------------------------------------
> >
> >
> >
> http://git-wip-us.apache.org/repos/asf/crunch/blob/0251bc60/crunch-core/src/main/java/org/apache/crunch/lib/sort/ReverseAvroComparator.java
> > ----------------------------------------------------------------------
> > diff --git
> a/crunch-core/src/main/java/org/apache/crunch/lib/sort/ReverseAvroComparator.java
> b/crunch-core/src/main/java/org/apache/crunch/lib/sort/ReverseAvroComparator.java
> > index d83071b..ca6ba33 100644
> > ---
> a/crunch-core/src/main/java/org/apache/crunch/lib/sort/ReverseAvroComparator.java
> > +++
> b/crunch-core/src/main/java/org/apache/crunch/lib/sort/ReverseAvroComparator.java
> > @@ -1,16 +1,19 @@
> >  /**
> > - * Copyright (c) 2013, Cloudera, Inc. All Rights Reserved.
> > - *
> > - * Cloudera, Inc. 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 to the Apache Software Foundation (ASF) under one
> > + * or more contributor license agreements.  See the NOTICE file
> > + * distributed with this work for additional information
> > + * regarding copyright ownership.  The ASF licenses this file
> > + * to you under the Apache License, Version 2.0 (the
> > + * "License"); you may not use this file except in compliance
> > + * with the License.  You may obtain a copy of the License at
> >   *
> >   *     http://www.apache.org/licenses/LICENSE-2.0
> >   *
> > - * This software 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.crunch.lib.sort;
> >
> >
> >
> http://git-wip-us.apache.org/repos/asf/crunch/blob/0251bc60/crunch-core/src/main/java/org/apache/crunch/lib/sort/ReverseWritableComparator.java
> > ----------------------------------------------------------------------
> > diff --git
> a/crunch-core/src/main/java/org/apache/crunch/lib/sort/ReverseWritableComparator.java
> b/crunch-core/src/main/java/org/apache/crunch/lib/sort/ReverseWritableComparator.java
> > index c2d0c46..f356fc5 100644
> > ---
> a/crunch-core/src/main/java/org/apache/crunch/lib/sort/ReverseWritableComparator.java
> > +++
> b/crunch-core/src/main/java/org/apache/crunch/lib/sort/ReverseWritableComparator.java
> > @@ -1,16 +1,19 @@
> >  /**
> > - * Copyright (c) 2013, Cloudera, Inc. All Rights Reserved.
> > - *
> > - * Cloudera, Inc. 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 to the Apache Software Foundation (ASF) under one
> > + * or more contributor license agreements.  See the NOTICE file
> > + * distributed with this work for additional information
> > + * regarding copyright ownership.  The ASF licenses this file
> > + * to you under the Apache License, Version 2.0 (the
> > + * "License"); you may not use this file except in compliance
> > + * with the License.  You may obtain a copy of the License at
> >   *
> >   *     http://www.apache.org/licenses/LICENSE-2.0
> >   *
> > - * This software 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.crunch.lib.sort;
> >
> >
>

Re: [2/2] git commit: Fix license headers

Posted by Matthias Friedrich <ma...@mafr.de>.
Hmm, it seems there's still one with Cloudera license header left:

crunch-hbase/src/main/java/org/apache/crunch/io/hbase/TableOutputFormat.java

What do we do release-wise?

Regards,
  Matthias

On Tuesday, 2013-05-07, jwills@apache.org wrote:
> Fix license headers
> 
> 
> Project: http://git-wip-us.apache.org/repos/asf/crunch/repo
> Commit: http://git-wip-us.apache.org/repos/asf/crunch/commit/0251bc60
> Tree: http://git-wip-us.apache.org/repos/asf/crunch/tree/0251bc60
> Diff: http://git-wip-us.apache.org/repos/asf/crunch/diff/0251bc60
> 
> Branch: refs/heads/master
> Commit: 0251bc604b67a1d433f25e432271a67239fdafd1
> Parents: 7bb1dcf
> Author: Josh Wills <jw...@apache.org>
> Authored: Mon May 6 21:39:26 2013 -0700
> Committer: Josh Wills <jw...@apache.org>
> Committed: Mon May 6 21:39:26 2013 -0700
> 
> ----------------------------------------------------------------------
>  .../crunch/lib/sort/ReverseAvroComparator.java     |   21 ++++++++------
>  .../crunch/lib/sort/ReverseWritableComparator.java |   21 ++++++++------
>  2 files changed, 24 insertions(+), 18 deletions(-)
> ----------------------------------------------------------------------
> 
> 
> http://git-wip-us.apache.org/repos/asf/crunch/blob/0251bc60/crunch-core/src/main/java/org/apache/crunch/lib/sort/ReverseAvroComparator.java
> ----------------------------------------------------------------------
> diff --git a/crunch-core/src/main/java/org/apache/crunch/lib/sort/ReverseAvroComparator.java b/crunch-core/src/main/java/org/apache/crunch/lib/sort/ReverseAvroComparator.java
> index d83071b..ca6ba33 100644
> --- a/crunch-core/src/main/java/org/apache/crunch/lib/sort/ReverseAvroComparator.java
> +++ b/crunch-core/src/main/java/org/apache/crunch/lib/sort/ReverseAvroComparator.java
> @@ -1,16 +1,19 @@
>  /**
> - * Copyright (c) 2013, Cloudera, Inc. All Rights Reserved.
> - *
> - * Cloudera, Inc. 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 to the Apache Software Foundation (ASF) under one
> + * or more contributor license agreements.  See the NOTICE file
> + * distributed with this work for additional information
> + * regarding copyright ownership.  The ASF licenses this file
> + * to you under the Apache License, Version 2.0 (the
> + * "License"); you may not use this file except in compliance
> + * with the License.  You may obtain a copy of the License at
>   *
>   *     http://www.apache.org/licenses/LICENSE-2.0
>   *
> - * This software 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.crunch.lib.sort;
>  
> 
> http://git-wip-us.apache.org/repos/asf/crunch/blob/0251bc60/crunch-core/src/main/java/org/apache/crunch/lib/sort/ReverseWritableComparator.java
> ----------------------------------------------------------------------
> diff --git a/crunch-core/src/main/java/org/apache/crunch/lib/sort/ReverseWritableComparator.java b/crunch-core/src/main/java/org/apache/crunch/lib/sort/ReverseWritableComparator.java
> index c2d0c46..f356fc5 100644
> --- a/crunch-core/src/main/java/org/apache/crunch/lib/sort/ReverseWritableComparator.java
> +++ b/crunch-core/src/main/java/org/apache/crunch/lib/sort/ReverseWritableComparator.java
> @@ -1,16 +1,19 @@
>  /**
> - * Copyright (c) 2013, Cloudera, Inc. All Rights Reserved.
> - *
> - * Cloudera, Inc. 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 to the Apache Software Foundation (ASF) under one
> + * or more contributor license agreements.  See the NOTICE file
> + * distributed with this work for additional information
> + * regarding copyright ownership.  The ASF licenses this file
> + * to you under the Apache License, Version 2.0 (the
> + * "License"); you may not use this file except in compliance
> + * with the License.  You may obtain a copy of the License at
>   *
>   *     http://www.apache.org/licenses/LICENSE-2.0
>   *
> - * This software 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.crunch.lib.sort;
>  
> 

[2/2] git commit: Fix license headers

Posted by jw...@apache.org.
Fix license headers


Project: http://git-wip-us.apache.org/repos/asf/crunch/repo
Commit: http://git-wip-us.apache.org/repos/asf/crunch/commit/0251bc60
Tree: http://git-wip-us.apache.org/repos/asf/crunch/tree/0251bc60
Diff: http://git-wip-us.apache.org/repos/asf/crunch/diff/0251bc60

Branch: refs/heads/master
Commit: 0251bc604b67a1d433f25e432271a67239fdafd1
Parents: 7bb1dcf
Author: Josh Wills <jw...@apache.org>
Authored: Mon May 6 21:39:26 2013 -0700
Committer: Josh Wills <jw...@apache.org>
Committed: Mon May 6 21:39:26 2013 -0700

----------------------------------------------------------------------
 .../crunch/lib/sort/ReverseAvroComparator.java     |   21 ++++++++------
 .../crunch/lib/sort/ReverseWritableComparator.java |   21 ++++++++------
 2 files changed, 24 insertions(+), 18 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/crunch/blob/0251bc60/crunch-core/src/main/java/org/apache/crunch/lib/sort/ReverseAvroComparator.java
----------------------------------------------------------------------
diff --git a/crunch-core/src/main/java/org/apache/crunch/lib/sort/ReverseAvroComparator.java b/crunch-core/src/main/java/org/apache/crunch/lib/sort/ReverseAvroComparator.java
index d83071b..ca6ba33 100644
--- a/crunch-core/src/main/java/org/apache/crunch/lib/sort/ReverseAvroComparator.java
+++ b/crunch-core/src/main/java/org/apache/crunch/lib/sort/ReverseAvroComparator.java
@@ -1,16 +1,19 @@
 /**
- * Copyright (c) 2013, Cloudera, Inc. All Rights Reserved.
- *
- * Cloudera, Inc. 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 to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
  *     http://www.apache.org/licenses/LICENSE-2.0
  *
- * This software 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.crunch.lib.sort;
 

http://git-wip-us.apache.org/repos/asf/crunch/blob/0251bc60/crunch-core/src/main/java/org/apache/crunch/lib/sort/ReverseWritableComparator.java
----------------------------------------------------------------------
diff --git a/crunch-core/src/main/java/org/apache/crunch/lib/sort/ReverseWritableComparator.java b/crunch-core/src/main/java/org/apache/crunch/lib/sort/ReverseWritableComparator.java
index c2d0c46..f356fc5 100644
--- a/crunch-core/src/main/java/org/apache/crunch/lib/sort/ReverseWritableComparator.java
+++ b/crunch-core/src/main/java/org/apache/crunch/lib/sort/ReverseWritableComparator.java
@@ -1,16 +1,19 @@
 /**
- * Copyright (c) 2013, Cloudera, Inc. All Rights Reserved.
- *
- * Cloudera, Inc. 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 to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
  *     http://www.apache.org/licenses/LICENSE-2.0
  *
- * This software 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.crunch.lib.sort;