You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@cassandra.apache.org by sl...@apache.org on 2016/12/08 08:18:47 UTC

cassandra git commit: Paxos regression from CASSANDRA-12716

Repository: cassandra
Updated Branches:
  refs/heads/trunk 7a6ad9e65 -> 717e1320e


Paxos regression from CASSANDRA-12716

patch by Sylvain Lebresne; reviewed by Joel Knighton for CASSANDRA-13012


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

Branch: refs/heads/trunk
Commit: 717e1320ea9802fa0e334ba7bd124d19f763cb2f
Parents: 7a6ad9e
Author: Sylvain Lebresne <sy...@datastax.com>
Authored: Wed Dec 7 10:17:23 2016 +0100
Committer: Sylvain Lebresne <sy...@datastax.com>
Committed: Thu Dec 8 09:18:17 2016 +0100

----------------------------------------------------------------------
 src/java/org/apache/cassandra/db/SystemKeyspace.java | 8 --------
 1 file changed, 8 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/cassandra/blob/717e1320/src/java/org/apache/cassandra/db/SystemKeyspace.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/db/SystemKeyspace.java b/src/java/org/apache/cassandra/db/SystemKeyspace.java
index 2eb12b9..c845352 100644
--- a/src/java/org/apache/cassandra/db/SystemKeyspace.java
+++ b/src/java/org/apache/cassandra/db/SystemKeyspace.java
@@ -971,14 +971,6 @@ public final class SystemKeyspace
             return new PaxosState(key, metadata);
         UntypedResultSet.Row row = results.one();
 
-        // Note: Pre-3.0, we used to not store the versions at which things were serialized. As 3.0 is a mandatory
-        // upgrade to 4.0+ and the paxos table is TTLed, it's _very_ unlikely we'll ever read a proposal or MRC without
-        // a version. But if we do (say gc_grace, on which the TTL is based, happens to be super large), we consider
-        // the commit too old and ignore it.
-        if (!row.has("proposal_version") || !row.has("most_recent_commit_version"))
-            return new PaxosState(key, metadata);
-
-
         Commit promised = row.has("in_progress_ballot")
                         ? new Commit(row.getUUID("in_progress_ballot"), new PartitionUpdate(metadata, key, metadata.partitionColumns(), 1))
                         : Commit.emptyCommit(key, metadata);