You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@cassandra.apache.org by al...@apache.org on 2014/07/08 19:18:45 UTC

[1/3] git commit: Followup for CASSANDRA-7403

Repository: cassandra
Updated Branches:
  refs/heads/cassandra-2.1 ec38458d6 -> 04944f0ca


Followup for CASSANDRA-7403


Project: http://git-wip-us.apache.org/repos/asf/cassandra/repo
Commit: http://git-wip-us.apache.org/repos/asf/cassandra/commit/8733de64
Tree: http://git-wip-us.apache.org/repos/asf/cassandra/tree/8733de64
Diff: http://git-wip-us.apache.org/repos/asf/cassandra/diff/8733de64

Branch: refs/heads/cassandra-2.1
Commit: 8733de64409ad8fdca9ddbd3b5dd7476e3e33d77
Parents: 0bc4663
Author: Sylvain Lebresne <sy...@datastax.com>
Authored: Tue Jul 8 14:00:35 2014 +0200
Committer: Sylvain Lebresne <sy...@datastax.com>
Committed: Tue Jul 8 14:00:35 2014 +0200

----------------------------------------------------------------------
 .../apache/cassandra/db/BufferExpiringCell.java |  4 +--
 .../apache/cassandra/db/NativeExpiringCell.java |  4 +--
 .../AbstractSimplePerColumnSecondaryIndex.java  |  5 ++--
 .../db/index/SecondaryIndexManager.java         | 31 ++++++++++----------
 4 files changed, 23 insertions(+), 21 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/cassandra/blob/8733de64/src/java/org/apache/cassandra/db/BufferExpiringCell.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/db/BufferExpiringCell.java b/src/java/org/apache/cassandra/db/BufferExpiringCell.java
index a2b4f19..347604a 100644
--- a/src/java/org/apache/cassandra/db/BufferExpiringCell.java
+++ b/src/java/org/apache/cassandra/db/BufferExpiringCell.java
@@ -142,6 +142,7 @@ public class BufferExpiringCell extends BufferCell implements ExpiringCell
             throw new MarshalException("The local expiration time should not be negative");
     }
 
+    @Override
     public Cell reconcile(Cell cell)
     {
         long ts1 = timestamp(), ts2 = cell.timestamp();
@@ -150,11 +151,10 @@ public class BufferExpiringCell extends BufferCell implements ExpiringCell
         // we should prefer tombstones
         if (cell instanceof DeletedCell)
             return cell;
-        // however if we're both ExpiringCells, we should prefer the one with the longest ttl
-        // (really in preference _always_ to the value comparison)
         int c = value().compareTo(cell.value());
         if (c != 0)
             return c < 0 ? cell : this;
+        // If we have same timestamp and value, prefer the longest ttl
         if (cell instanceof ExpiringCell)
         {
             int let1 = localExpirationTime, let2 = cell.getLocalDeletionTime();

http://git-wip-us.apache.org/repos/asf/cassandra/blob/8733de64/src/java/org/apache/cassandra/db/NativeExpiringCell.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/db/NativeExpiringCell.java b/src/java/org/apache/cassandra/db/NativeExpiringCell.java
index 5648375..d97e080 100644
--- a/src/java/org/apache/cassandra/db/NativeExpiringCell.java
+++ b/src/java/org/apache/cassandra/db/NativeExpiringCell.java
@@ -128,6 +128,7 @@ public class NativeExpiringCell extends NativeCell implements ExpiringCell
         FBUtilities.updateWithInt(digest, getTimeToLive());
     }
 
+    @Override
     public Cell reconcile(Cell cell)
     {
         long ts1 = timestamp(), ts2 = cell.timestamp();
@@ -136,11 +137,10 @@ public class NativeExpiringCell extends NativeCell implements ExpiringCell
         // we should prefer tombstones
         if (cell instanceof DeletedCell)
             return cell;
-        // however if we're both ExpiringCells, we should prefer the one with the longest ttl
-        // (really in preference _always_ to the value comparison)
         int c = value().compareTo(cell.value());
         if (c != 0)
             return c < 0 ? cell : this;
+        // If we have same timestamp and value, prefer the longest ttl
         if (cell instanceof ExpiringCell)
         {
             int let1 = getLocalDeletionTime(), let2 = cell.getLocalDeletionTime();

http://git-wip-us.apache.org/repos/asf/cassandra/blob/8733de64/src/java/org/apache/cassandra/db/index/AbstractSimplePerColumnSecondaryIndex.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/db/index/AbstractSimplePerColumnSecondaryIndex.java b/src/java/org/apache/cassandra/db/index/AbstractSimplePerColumnSecondaryIndex.java
index b64d84f..a2011b6 100644
--- a/src/java/org/apache/cassandra/db/index/AbstractSimplePerColumnSecondaryIndex.java
+++ b/src/java/org/apache/cassandra/db/index/AbstractSimplePerColumnSecondaryIndex.java
@@ -121,11 +121,12 @@ public abstract class AbstractSimplePerColumnSecondaryIndex extends PerColumnSec
     }
 
     public void update(ByteBuffer rowKey, Cell oldCol, Cell col, OpOrder.Group opGroup)
-    {        
+    {
         // insert the new value before removing the old one, so we never have a period
         // where the row is invisible to both queries (the opposite seems preferable); see CASSANDRA-5540                    
         insert(rowKey, col, opGroup);
-        delete(rowKey, oldCol, opGroup);
+        if (SecondaryIndexManager.shouldCleanupOldValue(oldCol, col))
+            delete(rowKey, oldCol, opGroup);
     }
 
     public void removeIndex(ByteBuffer columnName)

http://git-wip-us.apache.org/repos/asf/cassandra/blob/8733de64/src/java/org/apache/cassandra/db/index/SecondaryIndexManager.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/db/index/SecondaryIndexManager.java b/src/java/org/apache/cassandra/db/index/SecondaryIndexManager.java
index f78dc86..d32306a 100644
--- a/src/java/org/apache/cassandra/db/index/SecondaryIndexManager.java
+++ b/src/java/org/apache/cassandra/db/index/SecondaryIndexManager.java
@@ -620,6 +620,22 @@ public class SecondaryIndexManager
         return true;
     }
 
+    static boolean shouldCleanupOldValue(Cell oldCell, Cell newCell)
+    {
+        // If any one of name/value/timestamp are different, then we
+        // should delete from the index. If not, then we can infer that
+        // at least one of the cells is an ExpiringColumn and that the
+        // difference is in the expiry time. In this case, we don't want to
+        // delete the old value from the index as the tombstone we insert
+        // will just hide the inserted value.
+        // Completely identical cells (including expiring columns with
+        // identical ttl & localExpirationTime) will not get this far due
+        // to the oldCell.equals(newColumn) in StandardUpdater.update
+        return !oldCell.name().equals(newCell.name())
+            || !oldCell.value().equals(newCell.value())
+            || oldCell.timestamp() != newCell.timestamp();
+    }
+
     public static interface Updater
     {
         /** called when constructing the index against pre-existing data */
@@ -744,20 +760,5 @@ public class SecondaryIndexManager
                 ((PerRowSecondaryIndex) index).index(key.getKey(), cf);
         }
 
-        private boolean shouldCleanupOldValue(Cell oldCell, Cell newCell)
-        {
-            // If any one of name/value/timestamp are different, then we
-            // should delete from the index. If not, then we can infer that
-            // at least one of the cells is an ExpiringColumn and that the
-            // difference is in the expiry time. In this case, we don't want to
-            // delete the old value from the index as the tombstone we insert
-            // will just hide the inserted value.
-            // Completely identical cells (including expiring columns with
-            // identical ttl & localExpirationTime) will not get this far due
-            // to the oldCell.equals(newColumn) in StandardUpdater.update
-            return !oldCell.name().equals(newCell.name())
-                || !oldCell.value().equals(newCell.value())
-                || oldCell.timestamp() != newCell.timestamp();
-        }
     }
 }


[2/3] git commit: Update versions and licenses for 2.1 RC3 release

Posted by al...@apache.org.
Update versions and licenses for 2.1 RC3 release


Project: http://git-wip-us.apache.org/repos/asf/cassandra/repo
Commit: http://git-wip-us.apache.org/repos/asf/cassandra/commit/0bc98414
Tree: http://git-wip-us.apache.org/repos/asf/cassandra/tree/0bc98414
Diff: http://git-wip-us.apache.org/repos/asf/cassandra/diff/0bc98414

Branch: refs/heads/cassandra-2.1
Commit: 0bc98414cee3dfc2e7b743473939466f02b0d5be
Parents: 8733de6
Author: Sylvain Lebresne <sy...@datastax.com>
Authored: Tue Jul 8 14:07:17 2014 +0200
Committer: Sylvain Lebresne <sy...@datastax.com>
Committed: Tue Jul 8 14:07:17 2014 +0200

----------------------------------------------------------------------
 .rat-excludes                                   |  2 ++
 build.xml                                       |  2 +-
 debian/changelog                                |  6 ++++++
 test/unit/org/apache/cassandra/db/CellTest.java | 21 ++++++++++++++++++++
 .../stress/generate/DistributionInverted.java   | 21 ++++++++++++++++++++
 .../cassandra/stress/generate/Partition.java    | 21 ++++++++++++++++++++
 .../stress/generate/PartitionGenerator.java     | 21 ++++++++++++++++++++
 .../stress/generate/RatioDistribution.java      | 21 ++++++++++++++++++++
 .../apache/cassandra/stress/generate/Row.java   | 21 ++++++++++++++++++++
 .../stress/generate/SeedGenerator.java          | 21 ++++++++++++++++++++
 .../stress/generate/SeedRandomGenerator.java    | 21 ++++++++++++++++++++
 .../stress/generate/SeedSeriesGenerator.java    | 21 ++++++++++++++++++++
 .../stress/generate/values/Generator.java       | 21 ++++++++++++++++++++
 .../stress/operations/FixedOpDistribution.java  | 21 ++++++++++++++++++++
 .../stress/operations/OpDistribution.java       | 21 ++++++++++++++++++++
 .../operations/OpDistributionFactory.java       | 21 ++++++++++++++++++++
 .../operations/SampledOpDistribution.java       | 21 ++++++++++++++++++++
 .../SampledOpDistributionFactory.java           | 21 ++++++++++++++++++++
 .../operations/userdefined/SchemaInsert.java    | 21 ++++++++++++++++++++
 .../operations/userdefined/SchemaQuery.java     | 21 ++++++++++++++++++++
 .../operations/userdefined/SchemaStatement.java | 21 ++++++++++++++++++++
 .../stress/settings/OptionAnyProbabilities.java | 21 ++++++++++++++++++++
 .../settings/OptionEnumProbabilities.java       | 21 ++++++++++++++++++++
 .../stress/settings/ValidationType.java         | 21 ++++++++++++++++++++
 24 files changed, 450 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/cassandra/blob/0bc98414/.rat-excludes
----------------------------------------------------------------------
diff --git a/.rat-excludes b/.rat-excludes
index 0da5ab9..d95b499 100644
--- a/.rat-excludes
+++ b/.rat-excludes
@@ -30,3 +30,5 @@ examples/triggers/conf/*
 examples/hadoop_word_count/conf/log4j.properties
 pylib/cqlshlib/test/**
 src/resources/org/apache/cassandra/config/version.properties
+conf/hotspot_compiler
+**/*-example.yaml

http://git-wip-us.apache.org/repos/asf/cassandra/blob/0bc98414/build.xml
----------------------------------------------------------------------
diff --git a/build.xml b/build.xml
index daf0516..d81c3d4 100644
--- a/build.xml
+++ b/build.xml
@@ -25,7 +25,7 @@
     <property name="debuglevel" value="source,lines,vars"/>
 
     <!-- default version and SCM information -->
-    <property name="base.version" value="2.1.0-rc2"/>
+    <property name="base.version" value="2.1.0-rc3"/>
     <property name="scm.connection" value="scm:git://git.apache.org/cassandra.git"/>
     <property name="scm.developerConnection" value="scm:git://git.apache.org/cassandra.git"/>
     <property name="scm.url" value="http://git-wip-us.apache.org/repos/asf?p=cassandra.git;a=tree"/>

http://git-wip-us.apache.org/repos/asf/cassandra/blob/0bc98414/debian/changelog
----------------------------------------------------------------------
diff --git a/debian/changelog b/debian/changelog
index 845115b..6f8e3ec 100644
--- a/debian/changelog
+++ b/debian/changelog
@@ -1,3 +1,9 @@
+cassandra (2.1.0~rc3) unstable; urgency=medium
+
+  * New RC release
+
+ -- Sylvain Lebresne <sl...@apache.org>  Tue, 08 Jul 2014 14:04:10 +0200
+
 cassandra (2.1.0~rc2) unstable; urgency=medium
 
   * New RC release

http://git-wip-us.apache.org/repos/asf/cassandra/blob/0bc98414/test/unit/org/apache/cassandra/db/CellTest.java
----------------------------------------------------------------------
diff --git a/test/unit/org/apache/cassandra/db/CellTest.java b/test/unit/org/apache/cassandra/db/CellTest.java
index 668bebc..63d6f4c 100644
--- a/test/unit/org/apache/cassandra/db/CellTest.java
+++ b/test/unit/org/apache/cassandra/db/CellTest.java
@@ -1,4 +1,25 @@
 package org.apache.cassandra.db;
+/*
+ * 
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ * 
+ */
+
 
 import org.junit.Test;
 

http://git-wip-us.apache.org/repos/asf/cassandra/blob/0bc98414/tools/stress/src/org/apache/cassandra/stress/generate/DistributionInverted.java
----------------------------------------------------------------------
diff --git a/tools/stress/src/org/apache/cassandra/stress/generate/DistributionInverted.java b/tools/stress/src/org/apache/cassandra/stress/generate/DistributionInverted.java
index df52cb8..13fae0d 100644
--- a/tools/stress/src/org/apache/cassandra/stress/generate/DistributionInverted.java
+++ b/tools/stress/src/org/apache/cassandra/stress/generate/DistributionInverted.java
@@ -1,4 +1,25 @@
 package org.apache.cassandra.stress.generate;
+/*
+ * 
+ * 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.
+ * 
+ */
+
 
 public class DistributionInverted extends Distribution
 {

http://git-wip-us.apache.org/repos/asf/cassandra/blob/0bc98414/tools/stress/src/org/apache/cassandra/stress/generate/Partition.java
----------------------------------------------------------------------
diff --git a/tools/stress/src/org/apache/cassandra/stress/generate/Partition.java b/tools/stress/src/org/apache/cassandra/stress/generate/Partition.java
index 856d550..f05e95b 100644
--- a/tools/stress/src/org/apache/cassandra/stress/generate/Partition.java
+++ b/tools/stress/src/org/apache/cassandra/stress/generate/Partition.java
@@ -1,4 +1,25 @@
 package org.apache.cassandra.stress.generate;
+/*
+ * 
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ * 
+ */
+
 
 import java.nio.ByteBuffer;
 import java.util.ArrayDeque;

http://git-wip-us.apache.org/repos/asf/cassandra/blob/0bc98414/tools/stress/src/org/apache/cassandra/stress/generate/PartitionGenerator.java
----------------------------------------------------------------------
diff --git a/tools/stress/src/org/apache/cassandra/stress/generate/PartitionGenerator.java b/tools/stress/src/org/apache/cassandra/stress/generate/PartitionGenerator.java
index 78002fb..d05350d 100644
--- a/tools/stress/src/org/apache/cassandra/stress/generate/PartitionGenerator.java
+++ b/tools/stress/src/org/apache/cassandra/stress/generate/PartitionGenerator.java
@@ -1,4 +1,25 @@
 package org.apache.cassandra.stress.generate;
+/*
+ * 
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ * 
+ */
+
 
 import java.nio.ByteBuffer;
 import java.util.ArrayList;

http://git-wip-us.apache.org/repos/asf/cassandra/blob/0bc98414/tools/stress/src/org/apache/cassandra/stress/generate/RatioDistribution.java
----------------------------------------------------------------------
diff --git a/tools/stress/src/org/apache/cassandra/stress/generate/RatioDistribution.java b/tools/stress/src/org/apache/cassandra/stress/generate/RatioDistribution.java
index fb5a373..37ad4c5 100644
--- a/tools/stress/src/org/apache/cassandra/stress/generate/RatioDistribution.java
+++ b/tools/stress/src/org/apache/cassandra/stress/generate/RatioDistribution.java
@@ -1,4 +1,25 @@
 package org.apache.cassandra.stress.generate;
+/*
+ * 
+ * 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.
+ * 
+ */
+
 
 public class RatioDistribution
 {

http://git-wip-us.apache.org/repos/asf/cassandra/blob/0bc98414/tools/stress/src/org/apache/cassandra/stress/generate/Row.java
----------------------------------------------------------------------
diff --git a/tools/stress/src/org/apache/cassandra/stress/generate/Row.java b/tools/stress/src/org/apache/cassandra/stress/generate/Row.java
index d3b9a2a..421dbbf 100644
--- a/tools/stress/src/org/apache/cassandra/stress/generate/Row.java
+++ b/tools/stress/src/org/apache/cassandra/stress/generate/Row.java
@@ -1,4 +1,25 @@
 package org.apache.cassandra.stress.generate;
+/*
+ * 
+ * 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.
+ * 
+ */
+
 
 public class Row
 {

http://git-wip-us.apache.org/repos/asf/cassandra/blob/0bc98414/tools/stress/src/org/apache/cassandra/stress/generate/SeedGenerator.java
----------------------------------------------------------------------
diff --git a/tools/stress/src/org/apache/cassandra/stress/generate/SeedGenerator.java b/tools/stress/src/org/apache/cassandra/stress/generate/SeedGenerator.java
index 6c1bc7f..d579223 100644
--- a/tools/stress/src/org/apache/cassandra/stress/generate/SeedGenerator.java
+++ b/tools/stress/src/org/apache/cassandra/stress/generate/SeedGenerator.java
@@ -1,4 +1,25 @@
 package org.apache.cassandra.stress.generate;
+/*
+ * 
+ * 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.
+ * 
+ */
+
 
 public interface SeedGenerator
 {

http://git-wip-us.apache.org/repos/asf/cassandra/blob/0bc98414/tools/stress/src/org/apache/cassandra/stress/generate/SeedRandomGenerator.java
----------------------------------------------------------------------
diff --git a/tools/stress/src/org/apache/cassandra/stress/generate/SeedRandomGenerator.java b/tools/stress/src/org/apache/cassandra/stress/generate/SeedRandomGenerator.java
index bbaaeb8..b590ffa 100644
--- a/tools/stress/src/org/apache/cassandra/stress/generate/SeedRandomGenerator.java
+++ b/tools/stress/src/org/apache/cassandra/stress/generate/SeedRandomGenerator.java
@@ -1,4 +1,25 @@
 package org.apache.cassandra.stress.generate;
+/*
+ * 
+ * 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.
+ * 
+ */
+
 
 public class SeedRandomGenerator implements SeedGenerator
 {

http://git-wip-us.apache.org/repos/asf/cassandra/blob/0bc98414/tools/stress/src/org/apache/cassandra/stress/generate/SeedSeriesGenerator.java
----------------------------------------------------------------------
diff --git a/tools/stress/src/org/apache/cassandra/stress/generate/SeedSeriesGenerator.java b/tools/stress/src/org/apache/cassandra/stress/generate/SeedSeriesGenerator.java
index 27967d2..78a8784 100644
--- a/tools/stress/src/org/apache/cassandra/stress/generate/SeedSeriesGenerator.java
+++ b/tools/stress/src/org/apache/cassandra/stress/generate/SeedSeriesGenerator.java
@@ -1,4 +1,25 @@
 package org.apache.cassandra.stress.generate;
+/*
+ * 
+ * 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.
+ * 
+ */
+
 
 public class SeedSeriesGenerator implements SeedGenerator
 {

http://git-wip-us.apache.org/repos/asf/cassandra/blob/0bc98414/tools/stress/src/org/apache/cassandra/stress/generate/values/Generator.java
----------------------------------------------------------------------
diff --git a/tools/stress/src/org/apache/cassandra/stress/generate/values/Generator.java b/tools/stress/src/org/apache/cassandra/stress/generate/values/Generator.java
index 13343de..1040bb3 100644
--- a/tools/stress/src/org/apache/cassandra/stress/generate/values/Generator.java
+++ b/tools/stress/src/org/apache/cassandra/stress/generate/values/Generator.java
@@ -1,4 +1,25 @@
 package org.apache.cassandra.stress.generate.values;
+/*
+ * 
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ * 
+ */
+
 
 import org.apache.cassandra.db.marshal.AbstractType;
 import org.apache.cassandra.stress.generate.Distribution;

http://git-wip-us.apache.org/repos/asf/cassandra/blob/0bc98414/tools/stress/src/org/apache/cassandra/stress/operations/FixedOpDistribution.java
----------------------------------------------------------------------
diff --git a/tools/stress/src/org/apache/cassandra/stress/operations/FixedOpDistribution.java b/tools/stress/src/org/apache/cassandra/stress/operations/FixedOpDistribution.java
index 914d212..3212795 100644
--- a/tools/stress/src/org/apache/cassandra/stress/operations/FixedOpDistribution.java
+++ b/tools/stress/src/org/apache/cassandra/stress/operations/FixedOpDistribution.java
@@ -1,4 +1,25 @@
 package org.apache.cassandra.stress.operations;
+/*
+ * 
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ * 
+ */
+
 
 import org.apache.cassandra.stress.Operation;
 

http://git-wip-us.apache.org/repos/asf/cassandra/blob/0bc98414/tools/stress/src/org/apache/cassandra/stress/operations/OpDistribution.java
----------------------------------------------------------------------
diff --git a/tools/stress/src/org/apache/cassandra/stress/operations/OpDistribution.java b/tools/stress/src/org/apache/cassandra/stress/operations/OpDistribution.java
index a744f18..bcbd0bf 100644
--- a/tools/stress/src/org/apache/cassandra/stress/operations/OpDistribution.java
+++ b/tools/stress/src/org/apache/cassandra/stress/operations/OpDistribution.java
@@ -1,4 +1,25 @@
 package org.apache.cassandra.stress.operations;
+/*
+ * 
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ * 
+ */
+
 
 import org.apache.cassandra.stress.Operation;
 

http://git-wip-us.apache.org/repos/asf/cassandra/blob/0bc98414/tools/stress/src/org/apache/cassandra/stress/operations/OpDistributionFactory.java
----------------------------------------------------------------------
diff --git a/tools/stress/src/org/apache/cassandra/stress/operations/OpDistributionFactory.java b/tools/stress/src/org/apache/cassandra/stress/operations/OpDistributionFactory.java
index 08d5f56..afbae7d 100644
--- a/tools/stress/src/org/apache/cassandra/stress/operations/OpDistributionFactory.java
+++ b/tools/stress/src/org/apache/cassandra/stress/operations/OpDistributionFactory.java
@@ -1,4 +1,25 @@
 package org.apache.cassandra.stress.operations;
+/*
+ * 
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ * 
+ */
+
 
 import org.apache.cassandra.stress.util.Timer;
 

http://git-wip-us.apache.org/repos/asf/cassandra/blob/0bc98414/tools/stress/src/org/apache/cassandra/stress/operations/SampledOpDistribution.java
----------------------------------------------------------------------
diff --git a/tools/stress/src/org/apache/cassandra/stress/operations/SampledOpDistribution.java b/tools/stress/src/org/apache/cassandra/stress/operations/SampledOpDistribution.java
index 8bd2806..0bd64c5 100644
--- a/tools/stress/src/org/apache/cassandra/stress/operations/SampledOpDistribution.java
+++ b/tools/stress/src/org/apache/cassandra/stress/operations/SampledOpDistribution.java
@@ -1,4 +1,25 @@
 package org.apache.cassandra.stress.operations;
+/*
+ * 
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ * 
+ */
+
 
 import org.apache.commons.math3.distribution.EnumeratedDistribution;
 import org.apache.commons.math3.util.Pair;

http://git-wip-us.apache.org/repos/asf/cassandra/blob/0bc98414/tools/stress/src/org/apache/cassandra/stress/operations/SampledOpDistributionFactory.java
----------------------------------------------------------------------
diff --git a/tools/stress/src/org/apache/cassandra/stress/operations/SampledOpDistributionFactory.java b/tools/stress/src/org/apache/cassandra/stress/operations/SampledOpDistributionFactory.java
index 575da12..efc90bc 100644
--- a/tools/stress/src/org/apache/cassandra/stress/operations/SampledOpDistributionFactory.java
+++ b/tools/stress/src/org/apache/cassandra/stress/operations/SampledOpDistributionFactory.java
@@ -1,4 +1,25 @@
 package org.apache.cassandra.stress.operations;
+/*
+ * 
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ * 
+ */
+
 
 import java.util.ArrayList;
 import java.util.Collections;

http://git-wip-us.apache.org/repos/asf/cassandra/blob/0bc98414/tools/stress/src/org/apache/cassandra/stress/operations/userdefined/SchemaInsert.java
----------------------------------------------------------------------
diff --git a/tools/stress/src/org/apache/cassandra/stress/operations/userdefined/SchemaInsert.java b/tools/stress/src/org/apache/cassandra/stress/operations/userdefined/SchemaInsert.java
index 7c5efac..673dafe 100644
--- a/tools/stress/src/org/apache/cassandra/stress/operations/userdefined/SchemaInsert.java
+++ b/tools/stress/src/org/apache/cassandra/stress/operations/userdefined/SchemaInsert.java
@@ -1,4 +1,25 @@
 package org.apache.cassandra.stress.operations.userdefined;
+/*
+ * 
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ * 
+ */
+
 
 import java.io.IOException;
 import java.util.ArrayList;

http://git-wip-us.apache.org/repos/asf/cassandra/blob/0bc98414/tools/stress/src/org/apache/cassandra/stress/operations/userdefined/SchemaQuery.java
----------------------------------------------------------------------
diff --git a/tools/stress/src/org/apache/cassandra/stress/operations/userdefined/SchemaQuery.java b/tools/stress/src/org/apache/cassandra/stress/operations/userdefined/SchemaQuery.java
index 9cec39b..a047261 100644
--- a/tools/stress/src/org/apache/cassandra/stress/operations/userdefined/SchemaQuery.java
+++ b/tools/stress/src/org/apache/cassandra/stress/operations/userdefined/SchemaQuery.java
@@ -1,4 +1,25 @@
 package org.apache.cassandra.stress.operations.userdefined;
+/*
+ * 
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ * 
+ */
+
 
 import java.io.IOException;
 

http://git-wip-us.apache.org/repos/asf/cassandra/blob/0bc98414/tools/stress/src/org/apache/cassandra/stress/operations/userdefined/SchemaStatement.java
----------------------------------------------------------------------
diff --git a/tools/stress/src/org/apache/cassandra/stress/operations/userdefined/SchemaStatement.java b/tools/stress/src/org/apache/cassandra/stress/operations/userdefined/SchemaStatement.java
index aac40c5..2e0170c 100644
--- a/tools/stress/src/org/apache/cassandra/stress/operations/userdefined/SchemaStatement.java
+++ b/tools/stress/src/org/apache/cassandra/stress/operations/userdefined/SchemaStatement.java
@@ -1,4 +1,25 @@
 package org.apache.cassandra.stress.operations.userdefined;
+/*
+ * 
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ * 
+ */
+
 
 import java.io.IOException;
 import java.nio.ByteBuffer;

http://git-wip-us.apache.org/repos/asf/cassandra/blob/0bc98414/tools/stress/src/org/apache/cassandra/stress/settings/OptionAnyProbabilities.java
----------------------------------------------------------------------
diff --git a/tools/stress/src/org/apache/cassandra/stress/settings/OptionAnyProbabilities.java b/tools/stress/src/org/apache/cassandra/stress/settings/OptionAnyProbabilities.java
index a9af1bd..4e2ad64 100644
--- a/tools/stress/src/org/apache/cassandra/stress/settings/OptionAnyProbabilities.java
+++ b/tools/stress/src/org/apache/cassandra/stress/settings/OptionAnyProbabilities.java
@@ -1,4 +1,25 @@
 package org.apache.cassandra.stress.settings;
+/*
+ * 
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ * 
+ */
+
 
 import java.util.ArrayList;
 import java.util.Arrays;

http://git-wip-us.apache.org/repos/asf/cassandra/blob/0bc98414/tools/stress/src/org/apache/cassandra/stress/settings/OptionEnumProbabilities.java
----------------------------------------------------------------------
diff --git a/tools/stress/src/org/apache/cassandra/stress/settings/OptionEnumProbabilities.java b/tools/stress/src/org/apache/cassandra/stress/settings/OptionEnumProbabilities.java
index 88ebd34..b1c5c49 100644
--- a/tools/stress/src/org/apache/cassandra/stress/settings/OptionEnumProbabilities.java
+++ b/tools/stress/src/org/apache/cassandra/stress/settings/OptionEnumProbabilities.java
@@ -1,4 +1,25 @@
 package org.apache.cassandra.stress.settings;
+/*
+ * 
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ * 
+ */
+
 
 import java.util.ArrayList;
 import java.util.List;

http://git-wip-us.apache.org/repos/asf/cassandra/blob/0bc98414/tools/stress/src/org/apache/cassandra/stress/settings/ValidationType.java
----------------------------------------------------------------------
diff --git a/tools/stress/src/org/apache/cassandra/stress/settings/ValidationType.java b/tools/stress/src/org/apache/cassandra/stress/settings/ValidationType.java
index c22242d..710b717 100644
--- a/tools/stress/src/org/apache/cassandra/stress/settings/ValidationType.java
+++ b/tools/stress/src/org/apache/cassandra/stress/settings/ValidationType.java
@@ -1,4 +1,25 @@
 package org.apache.cassandra.stress.settings;
+/*
+ * 
+ * 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.
+ * 
+ */
+
 
 public enum ValidationType
 {


[3/3] git commit: Merge branch 'cassandra-2.1.0' into cassandra-2.1

Posted by al...@apache.org.
Merge branch 'cassandra-2.1.0' into cassandra-2.1


Project: http://git-wip-us.apache.org/repos/asf/cassandra/repo
Commit: http://git-wip-us.apache.org/repos/asf/cassandra/commit/04944f0c
Tree: http://git-wip-us.apache.org/repos/asf/cassandra/tree/04944f0c
Diff: http://git-wip-us.apache.org/repos/asf/cassandra/diff/04944f0c

Branch: refs/heads/cassandra-2.1
Commit: 04944f0ca990254aa51ee5f3791717db15437a89
Parents: ec38458 0bc9841
Author: Aleksey Yeschenko <al...@apache.org>
Authored: Tue Jul 8 20:17:36 2014 +0300
Committer: Aleksey Yeschenko <al...@apache.org>
Committed: Tue Jul 8 20:18:24 2014 +0300

----------------------------------------------------------------------
 .rat-excludes                                   |  2 ++
 CHANGES.txt                                     |  2 +-
 build.xml                                       |  2 +-
 debian/changelog                                |  6 ++++
 .../apache/cassandra/db/BufferExpiringCell.java |  4 +--
 .../apache/cassandra/db/NativeExpiringCell.java |  4 +--
 .../AbstractSimplePerColumnSecondaryIndex.java  |  5 ++--
 .../db/index/SecondaryIndexManager.java         | 31 ++++++++++----------
 test/unit/org/apache/cassandra/db/CellTest.java | 21 +++++++++++++
 .../stress/generate/DistributionInverted.java   | 21 +++++++++++++
 .../cassandra/stress/generate/Partition.java    | 21 +++++++++++++
 .../stress/generate/PartitionGenerator.java     | 21 +++++++++++++
 .../stress/generate/RatioDistribution.java      | 21 +++++++++++++
 .../apache/cassandra/stress/generate/Row.java   | 21 +++++++++++++
 .../stress/generate/SeedGenerator.java          | 21 +++++++++++++
 .../stress/generate/SeedRandomGenerator.java    | 21 +++++++++++++
 .../stress/generate/SeedSeriesGenerator.java    | 21 +++++++++++++
 .../stress/generate/values/Generator.java       | 21 +++++++++++++
 .../stress/operations/FixedOpDistribution.java  | 21 +++++++++++++
 .../stress/operations/OpDistribution.java       | 21 +++++++++++++
 .../operations/OpDistributionFactory.java       | 21 +++++++++++++
 .../operations/SampledOpDistribution.java       | 21 +++++++++++++
 .../SampledOpDistributionFactory.java           | 21 +++++++++++++
 .../operations/userdefined/SchemaInsert.java    | 21 +++++++++++++
 .../operations/userdefined/SchemaQuery.java     | 21 +++++++++++++
 .../operations/userdefined/SchemaStatement.java | 21 +++++++++++++
 .../stress/settings/OptionAnyProbabilities.java | 21 +++++++++++++
 .../settings/OptionEnumProbabilities.java       | 21 +++++++++++++
 .../stress/settings/ValidationType.java         | 21 +++++++++++++
 29 files changed, 474 insertions(+), 23 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/cassandra/blob/04944f0c/CHANGES.txt
----------------------------------------------------------------------
diff --cc CHANGES.txt
index a64eca3,641326e..6421b6f
--- a/CHANGES.txt
+++ b/CHANGES.txt
@@@ -1,9 -1,3 +1,10 @@@
 +2.1.1
 + * Improve schema merge performance (CASSANDRA-7444)
 + * Fix NPE when unknown prepared statement ID is used (CASSANDRA-7454)
 + * Adjust MT depth based on # of partition validating (CASSANDRA-5263)
 + * Optimise NativeCell comparisons (CASSANDRA-6755)
 +
++
  2.1.0-rc3
   * Consider expiry when reconciling otherwise equal cells (CASSANDRA-7403)
   * Introduce CQL support for stress tool (CASSANDRA-6146)

http://git-wip-us.apache.org/repos/asf/cassandra/blob/04944f0c/build.xml
----------------------------------------------------------------------