You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@activemq.apache.org by ch...@apache.org on 2010/07/15 22:35:46 UTC

svn commit: r964573 - in /activemq/sandbox/activemq-apollo-actor: apollo-hawtdb/src/main/scala/org/apache/activemq/apollo/store/hawtdb/Helpers.scala apollo-util/src/main/scala/org/apache/activemq/apollo/util/list/SequenceSet.java pom.xml

Author: chirino
Date: Thu Jul 15 20:35:45 2010
New Revision: 964573

URL: http://svn.apache.org/viewvc?rev=964573&view=rev
Log:
updating dependency versions

Modified:
    activemq/sandbox/activemq-apollo-actor/apollo-hawtdb/src/main/scala/org/apache/activemq/apollo/store/hawtdb/Helpers.scala
    activemq/sandbox/activemq-apollo-actor/apollo-util/src/main/scala/org/apache/activemq/apollo/util/list/SequenceSet.java
    activemq/sandbox/activemq-apollo-actor/pom.xml

Modified: activemq/sandbox/activemq-apollo-actor/apollo-hawtdb/src/main/scala/org/apache/activemq/apollo/store/hawtdb/Helpers.scala
URL: http://svn.apache.org/viewvc/activemq/sandbox/activemq-apollo-actor/apollo-hawtdb/src/main/scala/org/apache/activemq/apollo/store/hawtdb/Helpers.scala?rev=964573&r1=964572&r2=964573&view=diff
==============================================================================
--- activemq/sandbox/activemq-apollo-actor/apollo-hawtdb/src/main/scala/org/apache/activemq/apollo/store/hawtdb/Helpers.scala (original)
+++ activemq/sandbox/activemq-apollo-actor/apollo-hawtdb/src/main/scala/org/apache/activemq/apollo/store/hawtdb/Helpers.scala Thu Jul 15 20:35:45 2010
@@ -34,75 +34,6 @@ import org.apache.activemq.apollo.store.
  */
 object Helpers {
 
-  val QUEUE_RECORD_CODEC = new VariableCodec[QueueEntryRecord]() {
-    def decode(dataIn: DataInput): QueueEntryRecord = {
-      val rc = new QueueEntryRecord();
-      rc.queueKey = dataIn.readLong();
-      rc.messageKey = dataIn.readLong();
-      rc.size = dataIn.readInt();
-      //            if (dataIn.readBoolean()) {
-      //                rc.setTte(dataIn.readLong());
-      //            }
-      rc.redeliveries = dataIn.readShort();
-      if (dataIn.readBoolean()) {
-        rc.attachment = BUFFER_CODEC.decode(dataIn);
-      }
-      return rc;
-    }
-
-    def encode(value: QueueEntryRecord, dataOut: DataOutput) = {
-      dataOut.writeLong(value.queueKey);
-      dataOut.writeLong(value.messageKey);
-      dataOut.writeInt(value.size);
-      //            if (value.getTte() >= 0) {
-      //                dataOut.writeBoolean(true);
-      //                dataOut.writeLong(value.getTte());
-      //            } else {
-      //                dataOut.writeBoolean(false);
-      //            }
-      dataOut.writeShort(value.redeliveries);
-      if (value.attachment != null) {
-        dataOut.writeBoolean(true);
-        BUFFER_CODEC.encode(value.attachment, dataOut);
-      } else {
-        dataOut.writeBoolean(false);
-      }
-    }
-
-    def estimatedSize(value: QueueEntryRecord) = throw new UnsupportedOperationException()
-  }
-
-  val QUEUE_DESCRIPTOR_CODEC = new VariableCodec[QueueRecord]() {
-    def decode(dataIn: DataInput): QueueRecord = {
-      val record = new QueueRecord();
-      record.queueType = ASCII_BUFFER_CODEC.decode(dataIn);
-      record.name = ASCII_BUFFER_CODEC.decode(dataIn);
-      //            if (dataIn.readBoolean()) {
-      //                record.parent = ASCII_BUFFER_MARSHALLER.readPayload(dataIn)
-      //                record.setPartitionId(dataIn.readInt());
-      //            }
-      return record;
-    }
-
-    def encode(value: QueueRecord, dataOut: DataOutput) = {
-      ASCII_BUFFER_CODEC.encode(value.queueType, dataOut);
-      ASCII_BUFFER_CODEC.encode(value.name, dataOut);
-      //            if (value.parent != null) {
-      //                dataOut.writeBoolean(true);
-      //                ASCII_BUFFER_MARSHALLER.writePayload(value.parent, dataOut);
-      //                dataOut.writeInt(value.getPartitionKey());
-      //            } else {
-      //                dataOut.writeBoolean(false);
-      //            }
-    }
-
-    def estimatedSize(value: QueueRecord) = throw new UnsupportedOperationException()
-  };
-
-  val ASCII_BUFFER_CODEC = AsciiBufferCodec.INSTANCE;
-  val BUFFER_CODEC = BufferCodec.INSTANCE;
-
-
   implicit def toMessageRecord(pb: AddMessage.Getter): MessageRecord = {
     val rc = new MessageRecord
     rc.key = pb.getMessageKey

Modified: activemq/sandbox/activemq-apollo-actor/apollo-util/src/main/scala/org/apache/activemq/apollo/util/list/SequenceSet.java
URL: http://svn.apache.org/viewvc/activemq/sandbox/activemq-apollo-actor/apollo-util/src/main/scala/org/apache/activemq/apollo/util/list/SequenceSet.java?rev=964573&r1=964572&r2=964573&view=diff
==============================================================================
--- activemq/sandbox/activemq-apollo-actor/apollo-util/src/main/scala/org/apache/activemq/apollo/util/list/SequenceSet.java (original)
+++ activemq/sandbox/activemq-apollo-actor/apollo-util/src/main/scala/org/apache/activemq/apollo/util/list/SequenceSet.java Thu Jul 15 20:35:45 2010
@@ -81,6 +81,10 @@ public class SequenceSet extends LinkedN
             return rc;
         }
 
+        public boolean isEstimatedSizeSupported() {
+            return true;
+        }
+
         public boolean isDeepCopySupported() {
             return true;
         }

Modified: activemq/sandbox/activemq-apollo-actor/pom.xml
URL: http://svn.apache.org/viewvc/activemq/sandbox/activemq-apollo-actor/pom.xml?rev=964573&r1=964572&r2=964573&view=diff
==============================================================================
--- activemq/sandbox/activemq-apollo-actor/pom.xml (original)
+++ activemq/sandbox/activemq-apollo-actor/pom.xml Thu Jul 15 20:35:45 2010
@@ -43,9 +43,9 @@
     <projectName>Apache ActiveMQ</projectName>
 
     <!-- dependencies that track scala version changes -->
-    <scala-version>2.8.0.RC7</scala-version>
-    <scalatest-version>1.2-for-scala-2.8.0.RC6-SNAPSHOT</scalatest-version>
-    <cascal-version>1.2-Scala.2.8.0.RC7-SNAPSHOT</cascal-version>
+    <scala-version>2.8.0</scala-version>
+    <scalatest-version>1.2-for-scala-2.8.0.final-SNAPSHOT</scalatest-version>
+    <cascal-version>1.2-Scala.2.8.0-SNAPSHOT</cascal-version>
     
     <servicemix.kernel.version>1.1.0</servicemix.kernel.version>
     <spring-version>2.5.5</spring-version>
@@ -101,7 +101,7 @@
 
     <hawtdispatch-version>1.0-SNAPSHOT</hawtdispatch-version>
     <hawtdb-version>1.2-SNAPSHOT</hawtdb-version>
-    <hawtbuf-version>1.1-SNAPSHOT</hawtbuf-version>
+    <hawtbuf-version>1.1</hawtbuf-version>
     
     <jetty-version>6.1.22</jetty-version>
     <scalate-version>1.2-SNAPSHOT</scalate-version>