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 2006/03/22 00:21:29 UTC

svn commit: r387665 [1/9] - in /incubator/activemq/trunk: activecluster/src/java/org/apache/activecluster/impl/ activemq-core/src/main/java/org/apache/activemq/advisory/ activemq-core/src/main/java/org/apache/activemq/broker/jmx/ activemq-core/src/main...

Author: chirino
Date: Tue Mar 21 15:20:55 2006
New Revision: 387665

URL: http://svn.apache.org/viewcvs?rev=387665&view=rev
Log:
did a bunch of svn propset svn:eol-style native 

Modified:
    incubator/activemq/trunk/activecluster/src/java/org/apache/activecluster/impl/SimpleDestinationMarshaller.java   (contents, props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/advisory/ProducerEvent.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/advisory/ProducerEventSource.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/advisory/ProducerListener.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/advisory/ProducerStartedEvent.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/advisory/ProducerStoppedEvent.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/jmx/DestinationView.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/jmx/DestinationViewMBean.java   (contents, props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/jmx/DurableSubscriptionView.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/jmx/DurableSubscriptionViewMBean.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/jmx/InactiveDurableSubscriptionView.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/jmx/SubscriptionView.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/jmx/SubscriptionViewMBean.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/region/LockOwner.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/NetworkBridgeFilter.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/BytesMarshaller.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/ListContainer.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/MapContainer.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/Marshaller.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/ObjectMarshaller.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/RuntimeStoreException.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/Store.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/StoreFactory.java   (contents, props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/StringMarshaller.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/BadMagicException.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/ContainerCollectionSupport.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/ContainerEntrySet.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/ContainerEntrySetIterator.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/ContainerKeySet.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/ContainerKeySetIterator.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/ContainerListIterator.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/ContainerMapEntry.java   (contents, props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/ContainerValueCollection.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/ContainerValueCollectionIterator.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/FreeSpaceManager.java   (contents, props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/FreeSpaceTree.java   (contents, props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/Item.java   (contents, props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/ListContainerImpl.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/LocatableItem.java   (contents, props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/MapContainerImpl.java   (contents, props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/RootContainer.java   (contents, props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/StoreByteArrayInputStream.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/StoreByteArrayOutputStream.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/StoreImpl.java   (contents, props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/StoreReader.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/StoreWriter.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/network/ConnectionFilter.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/openwire/DataStreamMarshaller.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/openwire/v1/BaseDataStreamMarshaller.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/openwire/v1/DataStructureSupportMarshaller.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/openwire/v1/NetworkBridgeFilterMarshaller.java   (contents, props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/store/kahadaptor/AtomicIntegerMarshaller.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/store/kahadaptor/CommandMarshaller.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/store/kahadaptor/KahaMessageStore.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/store/kahadaptor/KahaPersistentAdaptor.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/store/kahadaptor/KahaTopicMessageStore.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/transport/udp/ResponseRedirectInterceptor.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/util/BrokerSupport.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/JmsQueueCompositeSendReceiveTest.java
    incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/LargeStreamletTest.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/advisory/ProducerListenerTest.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/kaha/ListContainerTest.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/kaha/LoadTest.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/kaha/Loader.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/kaha/MapContainerTest.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/kaha/StoreTest.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/openwire/v1/NetworkBridgeFilterTest.java   (contents, props changed)
    incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/perf/SlowConsumer.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/perf/SlowConsumerTopicTest.java   (props changed)
    incubator/activemq/trunk/activemq-core/src/test/java/org/apache/activemq/transport/tcp/InactivityMonitorTest.java   (props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/BrokerException.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/ActiveMQBytesMessage.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/ActiveMQDestination.cs   (props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/ActiveMQMapMessage.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/ActiveMQMessage.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/ActiveMQObjectMessage.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/ActiveMQQueue.cs   (props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/ActiveMQStreamMessage.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/ActiveMQTempDestination.cs   (props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/ActiveMQTempQueue.cs   (props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/ActiveMQTempTopic.cs   (props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/ActiveMQTextMessage.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/ActiveMQTopic.cs   (props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/BaseCommand.cs   (props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/BaseDataStructure.cs   (props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/BooleanExpression.cs   (props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/BrokerId.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/BrokerInfo.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/ConnectionError.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/ConnectionId.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/ConnectionInfo.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/ConsumerId.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/ConsumerInfo.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/ControlCommand.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/DataArrayResponse.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/DataResponse.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/DataStructureSupport.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/DestinationInfo.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/DiscoveryEvent.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/ExceptionResponse.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/FlushCommand.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/IntegerResponse.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/JournalQueueAck.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/JournalTopicAck.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/JournalTrace.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/JournalTransaction.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/KeepAliveInfo.cs   (props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/LastPartialCommand.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/LocalTransactionId.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/MarshallAware.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/Message.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/MessageAck.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/MessageDispatch.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/MessageDispatchNotification.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/MessageId.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/MessageReference.cs   (props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/NetworkBridgeFilter.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/PartialCommand.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/ProducerId.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/ProducerInfo.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/RemoveInfo.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/RemoveSubscriptionInfo.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/ReplayCommand.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/Response.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/SessionId.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/SessionInfo.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/ShutdownInfo.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/SubscriptionInfo.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/TransactionId.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/TransactionInfo.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/WireFormatInfo.cs   (props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/XATransactionId.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Commands/Xid.cs   (props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Dispatcher.cs   (props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/ISynchronization.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/OpenWire/BaseDataStreamMarshaller.cs   (props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/OpenWire/BooleanStream.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/OpenWire/EndianSupport.cs   (props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/OpenWire/MessagePropertyHelper.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/OpenWire/OpenWireBinaryReader.cs   (props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/OpenWire/OpenWireBinaryWriter.cs   (props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/OpenWire/OpenWireFormat.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/OpenWire/PrimitiveMap.cs   (props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/OpenWire/V1/DataStructureSupportMarshaller.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/OpenWire/V1/LastPartialCommandMarshaller.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/OpenWire/V1/MarshallerFactory.cs   (props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/OpenWire/V1/MessageDispatchNotificationMarshaller.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/OpenWire/V1/NetworkBridgeFilterMarshaller.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/OpenWire/V1/PartialCommandMarshaller.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/OpenWire/V1/ReplayCommandMarshaller.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/TransactionContext.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Transport/ITransportFactory.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Transport/LoggingTransport.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Transport/MutexTransport.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Transport/ResponseCorrelator.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Transport/Tcp/TcpTransport.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Transport/Tcp/TcpTransportFactory.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/ActiveMQ/Transport/TransportFilter.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/CommonAssemblyInfo.cs   (props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IBytesMessage.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IConnection.cs   (props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IConnectionFactory.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IDestination.cs   (props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IMapMessage.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IMessage.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IMessageConsumer.cs   (props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IMessageProducer.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IPrimitiveMap.cs   (props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IQueue.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/ISession.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IStartable.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/IStoppable.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/ITemporaryQueue.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/ITemporaryTopic.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/ITextMessage.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/ITopic.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/NMSConnectionException.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/main/csharp/NMS/NMSException.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/test/csharp/ActiveMQ/Commands/CommandTest.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/test/csharp/ActiveMQ/OpenWire/BooleanStreamTest.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/test/csharp/ActiveMQ/OpenWire/EndianTest.cs   (props changed)
    incubator/activemq/trunk/activemq-dotnet/src/test/csharp/ActiveMQ/OpenWire/PrimitiveMapTest.cs   (props changed)
    incubator/activemq/trunk/activemq-dotnet/src/test/csharp/ActiveMQ/TestMain.cs   (contents, props changed)
    incubator/activemq/trunk/activemq-dotnet/src/test/csharp/CommonAssemblyInfo.cs   (props changed)
    incubator/activemq/trunk/activemq-dotnet/src/test/csharp/NMS/AsyncConsumeTest.cs   (props changed)
    incubator/activemq/trunk/activemq-dotnet/src/test/csharp/NMS/BadConsumeTest.cs   (props changed)
    incubator/activemq/trunk/activemq-dotnet/src/test/csharp/NMS/BytesMessageTest.cs   (props changed)
    incubator/activemq/trunk/activemq-dotnet/src/test/csharp/NMS/ConsumerTest.cs   (props changed)
    incubator/activemq/trunk/activemq-dotnet/src/test/csharp/NMS/JMSPropertyTest.cs   (props changed)
    incubator/activemq/trunk/activemq-dotnet/src/test/csharp/NMS/JMSTestSupport.cs   (props changed)
    incubator/activemq/trunk/activemq-dotnet/src/test/csharp/NMS/MapMessageTest.cs   (props changed)
    incubator/activemq/trunk/activemq-dotnet/src/test/csharp/NMS/MessageTest.cs   (props changed)
    incubator/activemq/trunk/activemq-dotnet/src/test/csharp/NMS/TextMessage.cs   (props changed)
    incubator/activemq/trunk/activemq-dotnet/src/test/csharp/NMS/TransactionTest.cs   (props changed)
    incubator/activemq/trunk/activemq-optional/src/test/java/org/apache/activemq/transport/http/HttpJmsDurableTopicSendReceiveTest.java   (contents, props changed)
    incubator/activemq/trunk/activemq-optional/src/test/java/org/apache/activemq/transport/http/HttpPersistentSendAndReceiveTest.java   (contents, props changed)
    incubator/activemq/trunk/activemq-optional/src/test/java/org/apache/activemq/transport/https/HttpsJmsSendAndReceiveTest.java   (contents, props changed)
    incubator/activemq/trunk/activemq-optional/src/test/java/org/apache/activemq/transport/https/HttpsTransportBrokerTest.java   (contents, props changed)
    incubator/activemq/trunk/activemq-soaktest/src/test/java/org/apache/activemq/soaktest/MarshallingWithCachingTest.java   (contents, props changed)
    incubator/activemq/trunk/activemq-soaktest/src/test/java/org/apache/activemq/soaktest/PublishThenConsumeSoakTest.java   (contents, props changed)
    incubator/activemq/trunk/activemq-soaktest/src/test/java/org/apache/activemq/soaktest/SoakTestSupport.java   (contents, props changed)
    incubator/activemq/trunk/activemq-soaktest/src/test/java/org/apache/activemq/tool/Consumer.java   (contents, props changed)
    incubator/activemq/trunk/activemq-soaktest/src/test/java/org/apache/activemq/tool/Producer.java   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/command/NetworkBridgeFilter.cpp   (contents, props changed)
    incubator/activemq/trunk/openwire-cpp/src/marshal/NetworkBridgeFilterMarshaller.cpp   (contents, props changed)
    incubator/activemq/trunk/stomp/php/Stomp.php   (props changed)
    incubator/activemq/trunk/stomp/php/Test.php   (props changed)

Modified: incubator/activemq/trunk/activecluster/src/java/org/apache/activecluster/impl/SimpleDestinationMarshaller.java
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activecluster/src/java/org/apache/activecluster/impl/SimpleDestinationMarshaller.java?rev=387665&r1=387664&r2=387665&view=diff
==============================================================================
--- incubator/activemq/trunk/activecluster/src/java/org/apache/activecluster/impl/SimpleDestinationMarshaller.java (original)
+++ incubator/activemq/trunk/activecluster/src/java/org/apache/activecluster/impl/SimpleDestinationMarshaller.java Tue Mar 21 15:20:55 2006
@@ -1,75 +1,75 @@
-/**
- *
- * Copyright 2005-2006 The Apache Software Foundation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- * 
- * 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.activecluster.impl;
-
-
-
-import javax.jms.Destination;
-import javax.jms.JMSException;
-import javax.jms.Queue;
-import javax.jms.Topic;
-import org.apache.activecluster.DestinationMarshaller;
-import org.apache.activemq.command.ActiveMQTopic;
-import org.apache.commons.logging.Log;
-import org.apache.commons.logging.LogFactory;
-
-/**
- * A simple marshaller for Destinations
- *
- * @version $Revision: 1.5 $
- */
-public class SimpleDestinationMarshaller implements DestinationMarshaller {
-    private final static Log log = LogFactory.getLog(SimpleDestinationMarshaller.class);
-    /**
-     * Builds a destination from a destinationName
-     * @param destinationName 
-     *
-     * @return the destination to send messages to all members of the cluster
-     */
-    public Destination getDestination(String destinationName){
-        return new ActiveMQTopic(destinationName);
-    }
-
-    /**
-     * Gets a destination's physical name
-     * @param destination
-     * @return the destination's physical name
-     */
-    public String getDestinationName(Destination destination){
-        String result = null;
-        if (destination != null){
-            if (destination instanceof Topic){
-                Topic topic = (Topic) destination;
-                try{
-                    result = topic.getTopicName();
-                }catch(JMSException e){
-                    log.error("Failed to get topic name for " + destination,e);
-                }
-            }else{
-                Queue queue = (Queue) destination;
-                try{
-                    result = queue.getQueueName();
-                }catch(JMSException e){
-                    log.error("Failed to get queue name for " + destination,e);
-                }
-            }
-        }
-        return result;
-    }
+/**
+ *
+ * Copyright 2005-2006 The Apache Software Foundation
+ *
+ * Licensed under the Apache License, Version 2.0 (the "License");
+ * you may not use this file except in compliance with the License.
+ * You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * 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.activecluster.impl;
+
+
+
+import javax.jms.Destination;
+import javax.jms.JMSException;
+import javax.jms.Queue;
+import javax.jms.Topic;
+import org.apache.activecluster.DestinationMarshaller;
+import org.apache.activemq.command.ActiveMQTopic;
+import org.apache.commons.logging.Log;
+import org.apache.commons.logging.LogFactory;
+
+/**
+ * A simple marshaller for Destinations
+ *
+ * @version $Revision: 1.5 $
+ */
+public class SimpleDestinationMarshaller implements DestinationMarshaller {
+    private final static Log log = LogFactory.getLog(SimpleDestinationMarshaller.class);
+    /**
+     * Builds a destination from a destinationName
+     * @param destinationName 
+     *
+     * @return the destination to send messages to all members of the cluster
+     */
+    public Destination getDestination(String destinationName){
+        return new ActiveMQTopic(destinationName);
+    }
+
+    /**
+     * Gets a destination's physical name
+     * @param destination
+     * @return the destination's physical name
+     */
+    public String getDestinationName(Destination destination){
+        String result = null;
+        if (destination != null){
+            if (destination instanceof Topic){
+                Topic topic = (Topic) destination;
+                try{
+                    result = topic.getTopicName();
+                }catch(JMSException e){
+                    log.error("Failed to get topic name for " + destination,e);
+                }
+            }else{
+                Queue queue = (Queue) destination;
+                try{
+                    result = queue.getQueueName();
+                }catch(JMSException e){
+                    log.error("Failed to get queue name for " + destination,e);
+                }
+            }
+        }
+        return result;
+    }
 }

Propchange: incubator/activemq/trunk/activecluster/src/java/org/apache/activecluster/impl/SimpleDestinationMarshaller.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/advisory/ProducerEvent.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/advisory/ProducerEventSource.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/advisory/ProducerListener.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/advisory/ProducerStartedEvent.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/advisory/ProducerStoppedEvent.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/jmx/DestinationView.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/jmx/DestinationViewMBean.java
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/jmx/DestinationViewMBean.java?rev=387665&r1=387664&r2=387665&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/jmx/DestinationViewMBean.java (original)
+++ incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/jmx/DestinationViewMBean.java Tue Mar 21 15:20:55 2006
@@ -1,84 +1,84 @@
-/**
- *
- * Copyright 2005-2006 The Apache Software Foundation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * 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.activemq.broker.jmx;
-
-import java.util.Map;
-
-import javax.management.openmbean.CompositeData;
-import javax.management.openmbean.OpenDataException;
-import javax.management.openmbean.TabularData;
-
-
-public interface DestinationViewMBean {
-    
-	/**
-	 * Resets the managment counters.
-	 */
-    public void resetStatistics();
-
-    /**
-     * @return The number of messages that have been sent to the destination.
-     */
-    public long getEnqueueCount();
-
-    /**
-     * @return The number of messages that have been received from the destination.
-     */
-    public long getDequeueCount();
-
-    /**
-     * @return The number of consmers subscribed to messages from this destination.
-     */
-    public long getConsumerCount();
-
-    /**
-     * @return The number of messages being buffered by this destination
-     */
-    public long getQueueSize();
-    
-    /**
-     * @return An array of all the messages in the destination's queue.
-     */
-    public CompositeData[] browse() throws OpenDataException;
-    
-    /**
-     * @return A list of all the messages in the destination's queue.
-     */
-    public TabularData browseAsTable() throws OpenDataException;
-
-    /**
-     * Sends a TextMesage to the destination.
-     * @param body the text to send
-     * @return the message id of the message sent.
-     * @throws Exception
-     */
-    public String sendTextMessage(String body) throws Exception;
-
-    /**
-     * Sends a TextMesage to the destination.
-     * @param headers the message headers and properties to set.  Can only container Strings maped to primitive types.
-     * @param body the text to send
-     * @return the message id of the message sent.
-     * @throws Exception
-     */
-    public String sendTextMessage(Map headers, String body) throws Exception;
-
-    public int getMemoryPercentageUsed();
-    public long getMemoryLimit();
-    public void setMemoryLimit(long limit);
-
+/**
+ *
+ * Copyright 2005-2006 The Apache Software Foundation
+ *
+ * Licensed under the Apache License, Version 2.0 (the "License");
+ * you may not use this file except in compliance with the License.
+ * You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * 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.activemq.broker.jmx;
+
+import java.util.Map;
+
+import javax.management.openmbean.CompositeData;
+import javax.management.openmbean.OpenDataException;
+import javax.management.openmbean.TabularData;
+
+
+public interface DestinationViewMBean {
+    
+	/**
+	 * Resets the managment counters.
+	 */
+    public void resetStatistics();
+
+    /**
+     * @return The number of messages that have been sent to the destination.
+     */
+    public long getEnqueueCount();
+
+    /**
+     * @return The number of messages that have been received from the destination.
+     */
+    public long getDequeueCount();
+
+    /**
+     * @return The number of consmers subscribed to messages from this destination.
+     */
+    public long getConsumerCount();
+
+    /**
+     * @return The number of messages being buffered by this destination
+     */
+    public long getQueueSize();
+    
+    /**
+     * @return An array of all the messages in the destination's queue.
+     */
+    public CompositeData[] browse() throws OpenDataException;
+    
+    /**
+     * @return A list of all the messages in the destination's queue.
+     */
+    public TabularData browseAsTable() throws OpenDataException;
+
+    /**
+     * Sends a TextMesage to the destination.
+     * @param body the text to send
+     * @return the message id of the message sent.
+     * @throws Exception
+     */
+    public String sendTextMessage(String body) throws Exception;
+
+    /**
+     * Sends a TextMesage to the destination.
+     * @param headers the message headers and properties to set.  Can only container Strings maped to primitive types.
+     * @param body the text to send
+     * @return the message id of the message sent.
+     * @throws Exception
+     */
+    public String sendTextMessage(Map headers, String body) throws Exception;
+
+    public int getMemoryPercentageUsed();
+    public long getMemoryLimit();
+    public void setMemoryLimit(long limit);
+
 }

Propchange: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/jmx/DestinationViewMBean.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/jmx/DurableSubscriptionView.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/jmx/DurableSubscriptionViewMBean.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/jmx/InactiveDurableSubscriptionView.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/jmx/SubscriptionView.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/jmx/SubscriptionViewMBean.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/broker/region/LockOwner.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/command/NetworkBridgeFilter.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/BytesMarshaller.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/ListContainer.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/MapContainer.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/Marshaller.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/ObjectMarshaller.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/RuntimeStoreException.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/Store.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/StoreFactory.java
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/StoreFactory.java?rev=387665&r1=387664&r2=387665&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/StoreFactory.java (original)
+++ incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/StoreFactory.java Tue Mar 21 15:20:55 2006
@@ -1,47 +1,47 @@
-/**
- * 
- * Copyright 2005-2006 The Apache Software Foundation
- * 
- * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with
- * the License. You may obtain a copy of the License at
- * 
- * http://www.apache.org/licenses/LICENSE-2.0
- * 
- * 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.activemq.kaha;
-
-import java.io.File;
-import java.io.IOException;
-import org.apache.activemq.kaha.impl.StoreImpl;
-/**
- * Factory for creating stores
- * 
- * @version $Revision: 1.2 $
- */
-public class StoreFactory{
-   
-
-    /**
-     * open or create a Store
-     * @param name
-     * @param mode
-     * @return the opened/created store
-     * @throws IOException
-     */
-    public static Store open(String name,String mode) throws IOException{
-        return new StoreImpl(name,mode);
-    }
-    
-    /**
-     * Delete a database
-     * @param name of the database
-     * @return true if successful
-     */
-    public static boolean delete(String name){
-        File file = new File(name);
-        return file.delete();
-    }
-}
+/**
+ * 
+ * Copyright 2005-2006 The Apache Software Foundation
+ * 
+ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with
+ * the License. You may obtain a copy of the License at
+ * 
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * 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.activemq.kaha;
+
+import java.io.File;
+import java.io.IOException;
+import org.apache.activemq.kaha.impl.StoreImpl;
+/**
+ * Factory for creating stores
+ * 
+ * @version $Revision: 1.2 $
+ */
+public class StoreFactory{
+   
+
+    /**
+     * open or create a Store
+     * @param name
+     * @param mode
+     * @return the opened/created store
+     * @throws IOException
+     */
+    public static Store open(String name,String mode) throws IOException{
+        return new StoreImpl(name,mode);
+    }
+    
+    /**
+     * Delete a database
+     * @param name of the database
+     * @return true if successful
+     */
+    public static boolean delete(String name){
+        File file = new File(name);
+        return file.delete();
+    }
+}

Propchange: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/StoreFactory.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/StringMarshaller.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/BadMagicException.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/ContainerCollectionSupport.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/ContainerEntrySet.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/ContainerEntrySetIterator.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/ContainerKeySet.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/ContainerKeySetIterator.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/ContainerListIterator.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/ContainerMapEntry.java
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/ContainerMapEntry.java?rev=387665&r1=387664&r2=387665&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/ContainerMapEntry.java (original)
+++ incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/ContainerMapEntry.java Tue Mar 21 15:20:55 2006
@@ -1,50 +1,50 @@
-/**
- * 
- * Copyright 2005-2006 The Apache Software Foundation
- * 
- * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with
- * the License. You may obtain a copy of the License at
- * 
- * http://www.apache.org/licenses/LICENSE-2.0
- * 
- * 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.activemq.kaha.impl;
-
-import java.util.Map;
-import org.apache.activemq.kaha.MapContainer;
-
-/**
-* Map.Entry implementation for a container
-* 
-* @version $Revision: 1.2 $
-*/
-class ContainerMapEntry implements Map.Entry {
-
-    private MapContainer container;
-    private Object key;
-   
-    ContainerMapEntry(MapContainer container,Object key){
-        this.container = container;
-        this.key = key;
-      
-    }
-    
-    
-    public Object getKey(){
-        return key;
-    }
-
-    public Object getValue(){
-        return container.get(key);
-    }
-
-    public Object setValue(Object value){
-        return container.put(key, value);
-    }
-}
-   
-
-    
+/**
+ * 
+ * Copyright 2005-2006 The Apache Software Foundation
+ * 
+ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with
+ * the License. You may obtain a copy of the License at
+ * 
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * 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.activemq.kaha.impl;
+
+import java.util.Map;
+import org.apache.activemq.kaha.MapContainer;
+
+/**
+* Map.Entry implementation for a container
+* 
+* @version $Revision: 1.2 $
+*/
+class ContainerMapEntry implements Map.Entry {
+
+    private MapContainer container;
+    private Object key;
+   
+    ContainerMapEntry(MapContainer container,Object key){
+        this.container = container;
+        this.key = key;
+      
+    }
+    
+    
+    public Object getKey(){
+        return key;
+    }
+
+    public Object getValue(){
+        return container.get(key);
+    }
+
+    public Object setValue(Object value){
+        return container.put(key, value);
+    }
+}
+   
+
+    

Propchange: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/ContainerMapEntry.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/ContainerValueCollection.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/ContainerValueCollectionIterator.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/FreeSpaceManager.java
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/FreeSpaceManager.java?rev=387665&r1=387664&r2=387665&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/FreeSpaceManager.java (original)
+++ incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/FreeSpaceManager.java Tue Mar 21 15:20:55 2006
@@ -1,162 +1,162 @@
-/**
- * 
- * Copyright 2005-2006 The Apache Software Foundation
- * 
- * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with
- * the License. You may obtain a copy of the License at
- * 
- * http://www.apache.org/licenses/LICENSE-2.0
- * 
- * 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.activemq.kaha.impl;
-
-import java.io.IOException;
-import java.io.PrintWriter;
-import java.util.HashMap;
-import java.util.Iterator;
-import java.util.Map;
-import org.apache.commons.logging.Log;
-import org.apache.commons.logging.LogFactory;
-/**
- * Free space list in the Store
- * 
- * @version $Revision: 1.2 $
- */
-final class FreeSpaceManager{
-    private static final Log log = LogFactory.getLog(FreeSpaceManager.class);
-    static final int ROOT_SIZE=64;
-    static final int RESIZE_INCREMENT=4096*1024;
-    private Map map=new HashMap();
-    private Map prevMap=new HashMap();
-    private FreeSpaceTree tree=new FreeSpaceTree();
-    private StoreWriter writer;
-    private StoreReader reader;
-    private long dataEnd=ROOT_SIZE;
-    private long fileLength=-1;
-
-    FreeSpaceManager(StoreWriter writer,StoreReader reader) throws IOException{
-        this.writer=writer;
-        this.reader=reader;
-        this.fileLength=reader.length();
-    }
-
-    final Item getFreeSpace(Item item) throws IOException{
-        Item result=tree.getNextFreeSpace(item);
-        if(result==null){
-            while(dataEnd>=fileLength){
-                writer.allocateSpace(fileLength+RESIZE_INCREMENT);
-                fileLength=reader.length();
-            }
-            result=new Item();
-            result.setOffset(dataEnd);
-            int newSize = ((item.getSize()/8)+1)*8;
-
-            result.setSize(newSize);
-            dataEnd=dataEnd+result.getSize()+Item.HEAD_SIZE;
-        }else{
-            removeFreeSpace(result);
-        }
-        // reset the item
-        item.setActive(true);
-        item.setOffset(result.getOffset());
-        item.setSize(result.getSize());
-        return item;
-    }
-
-    final void addFreeSpace(Item item) throws IOException{
-        long currentOffset=reader.position();
-        reader.readHeader(item);
-        item.setActive(false);
-        // see if we can condense some space together
-        // first look for free space adjacent up the disk
-        Long nextKey=new Long(item.getOffset()+item.getSize()+Item.HEAD_SIZE);
-        Item next=(Item) map.remove(nextKey);
-        if(next!=null){
-            tree.removeItem(next);
-            Long prevKey=new Long(next.getOffset()+next.getSize()+Item.HEAD_SIZE);
-            prevMap.remove(prevKey);
-            int newSize=item.getSize()+next.getSize()+Item.HEAD_SIZE;
-            item.setSize(newSize);
-        }
-        // now see if there was a previous item
-        // in the next map
-        Long key=new Long(item.getOffset());
-        Item prev=(Item) prevMap.remove(key);
-        Long prevKey=prev!=null?new Long(prev.getOffset()):null;
-        if(prev!=null&&prevKey!=null){
-            // we can condense the free space
-            // first we are about to change the item so remove it from the tree
-            tree.removeItem(prev);
-            int newSize=prev.getSize()+item.getSize()+Item.HEAD_SIZE;
-            prev.setSize(newSize);
-            // update the header
-            writer.updateHeader(prev);
-            // put back in the tree
-            tree.addItem(prev);
-        }else{
-            // update the item header
-            writer.updateHeader(item);
-            tree.addItem(item);
-            map.put(key,item);
-            prevKey=new Long(item.getOffset()+item.getSize()+Item.HEAD_SIZE);
-            prevMap.put(prevKey,item);
-        }
-        reader.position(currentOffset);
-    }
-
-    /**
-     * validates and builds free list
-     * 
-     * @throws IOException
-     */
-    final void scanStoredItems() throws IOException{
-        if(reader.length()>ROOT_SIZE){
-            long offset=ROOT_SIZE;
-            while((offset+Item.HEAD_SIZE)<reader.length()){
-                Item item=new Item();
-                try{
-                    reader.position(offset);
-                    item.setOffset(offset);
-                    reader.readHeader(item);
-                }catch(BadMagicException e){
-                 
-                    log.error("Got bad magic reading stored items",e);
-                    break;
-                }
-                if(item.getSize()>=0){
-                    if(!item.isActive()){
-                        addFreeSpace(item);
-                    }
-                    offset+=item.getSize()+Item.HEAD_SIZE;
-                }else{
-                    // we've hit free space or end of file
-                    break;
-                }
-            }
-            dataEnd=offset;
-        }else {
-            dataEnd = ROOT_SIZE;
-        }
-    }
-
-    private void removeFreeSpace(Item item){
-        if(item!=null){
-            long next=item.getOffset()+item.getSize()+Item.HEAD_SIZE;
-            Long nextKey=new Long(next);
-            prevMap.remove(nextKey);
-            Long key=new Long(item.getOffset());
-            map.remove(key);
-        }
-    }
-
-    void dump(PrintWriter printer){
-        printer.println("FreeSpace: map size = "+map.size()+", tree size = "+tree.size()+", prevMap size = "
-                        +prevMap.size());
-        for(Iterator i=map.entrySet().iterator();i.hasNext();){
-            printer.println("map = "+i.next());
-        }
-    }
-}
+/**
+ * 
+ * Copyright 2005-2006 The Apache Software Foundation
+ * 
+ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with
+ * the License. You may obtain a copy of the License at
+ * 
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * 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.activemq.kaha.impl;
+
+import java.io.IOException;
+import java.io.PrintWriter;
+import java.util.HashMap;
+import java.util.Iterator;
+import java.util.Map;
+import org.apache.commons.logging.Log;
+import org.apache.commons.logging.LogFactory;
+/**
+ * Free space list in the Store
+ * 
+ * @version $Revision: 1.2 $
+ */
+final class FreeSpaceManager{
+    private static final Log log = LogFactory.getLog(FreeSpaceManager.class);
+    static final int ROOT_SIZE=64;
+    static final int RESIZE_INCREMENT=4096*1024;
+    private Map map=new HashMap();
+    private Map prevMap=new HashMap();
+    private FreeSpaceTree tree=new FreeSpaceTree();
+    private StoreWriter writer;
+    private StoreReader reader;
+    private long dataEnd=ROOT_SIZE;
+    private long fileLength=-1;
+
+    FreeSpaceManager(StoreWriter writer,StoreReader reader) throws IOException{
+        this.writer=writer;
+        this.reader=reader;
+        this.fileLength=reader.length();
+    }
+
+    final Item getFreeSpace(Item item) throws IOException{
+        Item result=tree.getNextFreeSpace(item);
+        if(result==null){
+            while(dataEnd>=fileLength){
+                writer.allocateSpace(fileLength+RESIZE_INCREMENT);
+                fileLength=reader.length();
+            }
+            result=new Item();
+            result.setOffset(dataEnd);
+            int newSize = ((item.getSize()/8)+1)*8;
+
+            result.setSize(newSize);
+            dataEnd=dataEnd+result.getSize()+Item.HEAD_SIZE;
+        }else{
+            removeFreeSpace(result);
+        }
+        // reset the item
+        item.setActive(true);
+        item.setOffset(result.getOffset());
+        item.setSize(result.getSize());
+        return item;
+    }
+
+    final void addFreeSpace(Item item) throws IOException{
+        long currentOffset=reader.position();
+        reader.readHeader(item);
+        item.setActive(false);
+        // see if we can condense some space together
+        // first look for free space adjacent up the disk
+        Long nextKey=new Long(item.getOffset()+item.getSize()+Item.HEAD_SIZE);
+        Item next=(Item) map.remove(nextKey);
+        if(next!=null){
+            tree.removeItem(next);
+            Long prevKey=new Long(next.getOffset()+next.getSize()+Item.HEAD_SIZE);
+            prevMap.remove(prevKey);
+            int newSize=item.getSize()+next.getSize()+Item.HEAD_SIZE;
+            item.setSize(newSize);
+        }
+        // now see if there was a previous item
+        // in the next map
+        Long key=new Long(item.getOffset());
+        Item prev=(Item) prevMap.remove(key);
+        Long prevKey=prev!=null?new Long(prev.getOffset()):null;
+        if(prev!=null&&prevKey!=null){
+            // we can condense the free space
+            // first we are about to change the item so remove it from the tree
+            tree.removeItem(prev);
+            int newSize=prev.getSize()+item.getSize()+Item.HEAD_SIZE;
+            prev.setSize(newSize);
+            // update the header
+            writer.updateHeader(prev);
+            // put back in the tree
+            tree.addItem(prev);
+        }else{
+            // update the item header
+            writer.updateHeader(item);
+            tree.addItem(item);
+            map.put(key,item);
+            prevKey=new Long(item.getOffset()+item.getSize()+Item.HEAD_SIZE);
+            prevMap.put(prevKey,item);
+        }
+        reader.position(currentOffset);
+    }
+
+    /**
+     * validates and builds free list
+     * 
+     * @throws IOException
+     */
+    final void scanStoredItems() throws IOException{
+        if(reader.length()>ROOT_SIZE){
+            long offset=ROOT_SIZE;
+            while((offset+Item.HEAD_SIZE)<reader.length()){
+                Item item=new Item();
+                try{
+                    reader.position(offset);
+                    item.setOffset(offset);
+                    reader.readHeader(item);
+                }catch(BadMagicException e){
+                 
+                    log.error("Got bad magic reading stored items",e);
+                    break;
+                }
+                if(item.getSize()>=0){
+                    if(!item.isActive()){
+                        addFreeSpace(item);
+                    }
+                    offset+=item.getSize()+Item.HEAD_SIZE;
+                }else{
+                    // we've hit free space or end of file
+                    break;
+                }
+            }
+            dataEnd=offset;
+        }else {
+            dataEnd = ROOT_SIZE;
+        }
+    }
+
+    private void removeFreeSpace(Item item){
+        if(item!=null){
+            long next=item.getOffset()+item.getSize()+Item.HEAD_SIZE;
+            Long nextKey=new Long(next);
+            prevMap.remove(nextKey);
+            Long key=new Long(item.getOffset());
+            map.remove(key);
+        }
+    }
+
+    void dump(PrintWriter printer){
+        printer.println("FreeSpace: map size = "+map.size()+", tree size = "+tree.size()+", prevMap size = "
+                        +prevMap.size());
+        for(Iterator i=map.entrySet().iterator();i.hasNext();){
+            printer.println("map = "+i.next());
+        }
+    }
+}

Propchange: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/FreeSpaceManager.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/FreeSpaceTree.java
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/FreeSpaceTree.java?rev=387665&r1=387664&r2=387665&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/FreeSpaceTree.java (original)
+++ incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/FreeSpaceTree.java Tue Mar 21 15:20:55 2006
@@ -1,109 +1,109 @@
-/**
- * 
- * Copyright 2005-2006 The Apache Software Foundation
- * 
- * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with
- * the License. You may obtain a copy of the License at
- * 
- * http://www.apache.org/licenses/LICENSE-2.0
- * 
- * 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.activemq.kaha.impl;
-
-import java.util.ArrayList;
-import java.util.HashMap;
-import java.util.Iterator;
-import java.util.List;
-import java.util.Map;
-import java.util.SortedMap;
-import java.util.TreeMap;
-/**
- * A a wrapper for a TreeMap of free Items - sorted by size This enables us to re-use free Items on disk
- * 
- * @version $Revision: 1.2 $
- */
-class FreeSpaceTree{
-    private Map sizeMap=new HashMap();
-    private TreeMap tree=new TreeMap();
-
-    void addItem(Item item){
-        Long sizeKey=new Long(item.getSize());
-        Item old=(Item) tree.put(sizeKey,item);
-        if(old!=null){
-            // We'll preserve old items to reuse
-            List list=(List) sizeMap.get(sizeKey);
-            if(list==null){
-                list=new ArrayList();
-                sizeMap.put(sizeKey,list);
-            }
-            list.add(old);
-        }
-    }
-
-    boolean removeItem(Item item){
-        boolean result=false;
-        Long sizeKey=new Long(item.getSize());
-        Item retrieved=(Item) tree.get(sizeKey);
-        if(retrieved==item){
-            Object foo=tree.remove(sizeKey);
-            if(foo!=retrieved){
-                Thread.dumpStack();
-                System.exit(0);
-            }
-            result=true;
-            reconfigureTree(sizeKey);
-        }else{
-            List list=(List) sizeMap.get(sizeKey);
-            if(list!=null){
-                boolean foo=list.remove(item);
-                if(list.isEmpty()){
-                    sizeMap.remove(sizeKey);
-                }
-            }
-        }
-        return result;
-    }
-
-    Item getNextFreeSpace(Item item){
-        Item result=null;
-        if(!tree.isEmpty()){
-            Long sizeKey=new Long(item.getSize());
-            SortedMap map=tree.tailMap(sizeKey);
-            if(map!=null&&!map.isEmpty()){
-                Long resultKey=(Long) map.firstKey();
-                result=(Item) map.get(resultKey);
-                if(result!=null){
-                    // remove from the tree
-                    tree.remove(resultKey);
-                    reconfigureTree(resultKey);
-                }
-            }
-        }
-        return result;
-    }
-
-    void reconfigureTree(Long sizeKey){
-        List list=(List) sizeMap.get(sizeKey);
-        if(list!=null){
-            if(!list.isEmpty()){
-                Object newItem=list.remove(list.size()-1);
-                tree.put(sizeKey,newItem);
-            }
-            if(list.isEmpty()){
-                sizeMap.remove(sizeKey);
-            }
-        }
-    }
-
-    int size(){
-        int result=0;
-        for(Iterator i=sizeMap.values().iterator();i.hasNext();){
-            List list=(List) i.next();
-            result+=list.size();
-        }
-        return result+tree.size();
-    }
+/**
+ * 
+ * Copyright 2005-2006 The Apache Software Foundation
+ * 
+ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with
+ * the License. You may obtain a copy of the License at
+ * 
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * 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.activemq.kaha.impl;
+
+import java.util.ArrayList;
+import java.util.HashMap;
+import java.util.Iterator;
+import java.util.List;
+import java.util.Map;
+import java.util.SortedMap;
+import java.util.TreeMap;
+/**
+ * A a wrapper for a TreeMap of free Items - sorted by size This enables us to re-use free Items on disk
+ * 
+ * @version $Revision: 1.2 $
+ */
+class FreeSpaceTree{
+    private Map sizeMap=new HashMap();
+    private TreeMap tree=new TreeMap();
+
+    void addItem(Item item){
+        Long sizeKey=new Long(item.getSize());
+        Item old=(Item) tree.put(sizeKey,item);
+        if(old!=null){
+            // We'll preserve old items to reuse
+            List list=(List) sizeMap.get(sizeKey);
+            if(list==null){
+                list=new ArrayList();
+                sizeMap.put(sizeKey,list);
+            }
+            list.add(old);
+        }
+    }
+
+    boolean removeItem(Item item){
+        boolean result=false;
+        Long sizeKey=new Long(item.getSize());
+        Item retrieved=(Item) tree.get(sizeKey);
+        if(retrieved==item){
+            Object foo=tree.remove(sizeKey);
+            if(foo!=retrieved){
+                Thread.dumpStack();
+                System.exit(0);
+            }
+            result=true;
+            reconfigureTree(sizeKey);
+        }else{
+            List list=(List) sizeMap.get(sizeKey);
+            if(list!=null){
+                boolean foo=list.remove(item);
+                if(list.isEmpty()){
+                    sizeMap.remove(sizeKey);
+                }
+            }
+        }
+        return result;
+    }
+
+    Item getNextFreeSpace(Item item){
+        Item result=null;
+        if(!tree.isEmpty()){
+            Long sizeKey=new Long(item.getSize());
+            SortedMap map=tree.tailMap(sizeKey);
+            if(map!=null&&!map.isEmpty()){
+                Long resultKey=(Long) map.firstKey();
+                result=(Item) map.get(resultKey);
+                if(result!=null){
+                    // remove from the tree
+                    tree.remove(resultKey);
+                    reconfigureTree(resultKey);
+                }
+            }
+        }
+        return result;
+    }
+
+    void reconfigureTree(Long sizeKey){
+        List list=(List) sizeMap.get(sizeKey);
+        if(list!=null){
+            if(!list.isEmpty()){
+                Object newItem=list.remove(list.size()-1);
+                tree.put(sizeKey,newItem);
+            }
+            if(list.isEmpty()){
+                sizeMap.remove(sizeKey);
+            }
+        }
+    }
+
+    int size(){
+        int result=0;
+        for(Iterator i=sizeMap.values().iterator();i.hasNext();){
+            List list=(List) i.next();
+            result+=list.size();
+        }
+        return result+tree.size();
+    }
 }

Propchange: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/FreeSpaceTree.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/Item.java
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/Item.java?rev=387665&r1=387664&r2=387665&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/Item.java (original)
+++ incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/Item.java Tue Mar 21 15:20:55 2006
@@ -1,116 +1,116 @@
-/**
- * 
- * Copyright 2005-2006 The Apache Software Foundation
- * 
- * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with
- * the License. You may obtain a copy of the License at
- * 
- * http://www.apache.org/licenses/LICENSE-2.0
- * 
- * 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.activemq.kaha.impl;
-
-import java.io.DataInput;
-import java.io.DataInputStream;
-import java.io.DataOutput;
-import java.io.DataOutputStream;
-import java.io.IOException;
-import org.apache.activemq.kaha.Marshaller;
-/**
- * A a wrapper for a data in the store
- * 
- * @version $Revision: 1.2 $
- */
-public class Item{
-    static final long POSITION_NOT_SET=-1;
-    static final short MAGIC=31317;
-    static final int ACTIVE=22;
-    static final int FREE=33;
-    static final int HEAD_SIZE=8; // magic + active + len
-    static final int LOCATION_SIZE=24;
-    private long offset=POSITION_NOT_SET;
-    private int size;
-    private boolean active;
-
-    Item(){}
-
-    void writeHeader(DataOutput dataOut) throws IOException{
-        dataOut.writeShort(MAGIC);
-        dataOut.writeByte(active?ACTIVE:FREE);
-        dataOut.writeInt(size);
-        dataOut.writeByte(0);//padding
-    }
-
-    void readHeader(DataInput dataIn) throws IOException{
-        int magic=dataIn.readShort();
-        if(magic==MAGIC){
-            active=(dataIn.readByte()==ACTIVE);
-            size=dataIn.readInt();
-        }else if (magic == 0){
-            size = -999; //end of data
-        }else{
-            throw new BadMagicException("Unexpected Magic value: "+magic);
-        }
-    }
-
-    void writePayload(Marshaller marshaller,Object object,DataOutputStream dataOut) throws IOException{
-        marshaller.writePayload(object,dataOut);
-    }
-
-    Object readPayload(Marshaller marshaller,DataInputStream dataIn) throws IOException{
-        return marshaller.readPayload(dataIn);
-    }
-
-    void readLocation(DataInput dataIn) throws IOException{}
-
-    void writeLocation(DataOutput dataOut) throws IOException{}
-
-    /**
-     * @return Returns the size.
-     */
-    int getSize(){
-        return size;
-    }
-
-    /**
-     * @param size
-     *            The size to set.
-     */
-    void setSize(int size){
-        this.size=size;
-    }
-
-    void setOffset(long pos){
-        offset=pos;
-    }
-
-    long getOffset(){
-        return offset;
-    }
-
-    /**
-     * @return Returns the active.
-     */
-    boolean isActive(){
-        return active;
-    }
-
-    /**
-     * @param active
-     *            The active to set.
-     */
-    void setActive(boolean active){
-        this.active=active;
-    }
-
-    /**
-     * @return a pretty print
-     */
-    public String toString(){
-        String result="offset = "+offset+" ,active = "+active+" , size = "+size;
-        return result;
-    }
+/**
+ * 
+ * Copyright 2005-2006 The Apache Software Foundation
+ * 
+ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with
+ * the License. You may obtain a copy of the License at
+ * 
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * 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.activemq.kaha.impl;
+
+import java.io.DataInput;
+import java.io.DataInputStream;
+import java.io.DataOutput;
+import java.io.DataOutputStream;
+import java.io.IOException;
+import org.apache.activemq.kaha.Marshaller;
+/**
+ * A a wrapper for a data in the store
+ * 
+ * @version $Revision: 1.2 $
+ */
+public class Item{
+    static final long POSITION_NOT_SET=-1;
+    static final short MAGIC=31317;
+    static final int ACTIVE=22;
+    static final int FREE=33;
+    static final int HEAD_SIZE=8; // magic + active + len
+    static final int LOCATION_SIZE=24;
+    private long offset=POSITION_NOT_SET;
+    private int size;
+    private boolean active;
+
+    Item(){}
+
+    void writeHeader(DataOutput dataOut) throws IOException{
+        dataOut.writeShort(MAGIC);
+        dataOut.writeByte(active?ACTIVE:FREE);
+        dataOut.writeInt(size);
+        dataOut.writeByte(0);//padding
+    }
+
+    void readHeader(DataInput dataIn) throws IOException{
+        int magic=dataIn.readShort();
+        if(magic==MAGIC){
+            active=(dataIn.readByte()==ACTIVE);
+            size=dataIn.readInt();
+        }else if (magic == 0){
+            size = -999; //end of data
+        }else{
+            throw new BadMagicException("Unexpected Magic value: "+magic);
+        }
+    }
+
+    void writePayload(Marshaller marshaller,Object object,DataOutputStream dataOut) throws IOException{
+        marshaller.writePayload(object,dataOut);
+    }
+
+    Object readPayload(Marshaller marshaller,DataInputStream dataIn) throws IOException{
+        return marshaller.readPayload(dataIn);
+    }
+
+    void readLocation(DataInput dataIn) throws IOException{}
+
+    void writeLocation(DataOutput dataOut) throws IOException{}
+
+    /**
+     * @return Returns the size.
+     */
+    int getSize(){
+        return size;
+    }
+
+    /**
+     * @param size
+     *            The size to set.
+     */
+    void setSize(int size){
+        this.size=size;
+    }
+
+    void setOffset(long pos){
+        offset=pos;
+    }
+
+    long getOffset(){
+        return offset;
+    }
+
+    /**
+     * @return Returns the active.
+     */
+    boolean isActive(){
+        return active;
+    }
+
+    /**
+     * @param active
+     *            The active to set.
+     */
+    void setActive(boolean active){
+        this.active=active;
+    }
+
+    /**
+     * @return a pretty print
+     */
+    public String toString(){
+        String result="offset = "+offset+" ,active = "+active+" , size = "+size;
+        return result;
+    }
 }

Propchange: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/Item.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/ListContainerImpl.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/LocatableItem.java
URL: http://svn.apache.org/viewcvs/incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/LocatableItem.java?rev=387665&r1=387664&r2=387665&view=diff
==============================================================================
--- incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/LocatableItem.java (original)
+++ incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/LocatableItem.java Tue Mar 21 15:20:55 2006
@@ -1,126 +1,126 @@
-/**
- * 
- * Copyright 2005-2006 The Apache Software Foundation
- * 
- * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with
- * the License. You may obtain a copy of the License at
- * 
- * http://www.apache.org/licenses/LICENSE-2.0
- * 
- * 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.activemq.kaha.impl;
-
-import java.io.DataInput;
-import java.io.DataInputStream;
-import java.io.DataOutput;
-import java.io.DataOutputStream;
-import java.io.Externalizable;
-import java.io.IOException;
-import java.io.ObjectInput;
-import java.io.ObjectOutput;
-import org.apache.activemq.kaha.Marshaller;
-
-/**
-* A an Item with a relative postion and location to other Items in the Store
-* 
-* @version $Revision: 1.2 $
-*/
-public final class LocatableItem extends Item implements Externalizable{
-    
-  
-    private static final long serialVersionUID=-6888731361600185708L;
-    private long previousItem=POSITION_NOT_SET;
-    private long nextItem=POSITION_NOT_SET;
-    private long referenceItem=POSITION_NOT_SET;
-   
-
-    public LocatableItem(){}
-
-    public LocatableItem(long prev,long next,long objOffset) throws IOException{
-        this.previousItem=prev;
-        this.nextItem=next;
-        this.referenceItem=objOffset;
-    }
-
-
-    public void writePayload(Marshaller marshaller,Object object,DataOutputStream dataOut) throws IOException{
-        dataOut.writeLong(previousItem);
-        dataOut.writeLong(nextItem);
-        dataOut.writeLong(referenceItem);
-        super.writePayload(marshaller,object,dataOut);
-    }
-
-    public Object readPayload(Marshaller marshaller,DataInputStream dataIn) throws IOException{
-        previousItem=dataIn.readLong();
-        nextItem=dataIn.readLong();
-        referenceItem=dataIn.readLong();
-        return super.readPayload(marshaller, dataIn);
-    }
-    
-    void readLocation(DataInput dataIn) throws IOException{
-        previousItem=dataIn.readLong();
-        nextItem=dataIn.readLong();
-        referenceItem=dataIn.readLong();
-    }
-
-    public void writeLocation(DataOutput dataOut) throws IOException{
-        dataOut.writeLong(previousItem);
-        dataOut.writeLong(nextItem);
-    }
-
-    public void setPreviousItem(long newPrevEntry){
-        previousItem=newPrevEntry;
-    }
-
-    public long getPreviousItem(){
-        return previousItem;
-    }
-
-    public void setNextItem(long newNextEntry){
-        nextItem=newNextEntry;
-    }
-
-    public long getNextItem(){
-        return nextItem;
-    }
-
-    public void setReferenceItem(long newObjectOffset){
-        referenceItem=newObjectOffset;
-    }
-
-    public long getReferenceItem(){
-        return referenceItem;
-    }
-
-    /* (non-Javadoc)
-     * @see org.apache.activemq.kaha.impl.Item#toString()
-     */
-    public String toString(){
-        String result=super.toString();
-        result+=" , referenceItem = "+referenceItem+", previousItem = "+previousItem+" , nextItem = "+nextItem;
-        return result;
-    }
-
-    /* (non-Javadoc)
-     * @see java.io.Externalizable#writeExternal(java.io.ObjectOutput)
-     */
-    public void writeExternal(ObjectOutput out) throws IOException{
-        out.writeLong(previousItem);
-        out.writeLong(nextItem);
-        out.writeLong(referenceItem);
-        
-    }
-
-    /* (non-Javadoc)
-     * @see java.io.Externalizable#readExternal(java.io.ObjectInput)
-     */
-    public void readExternal(ObjectInput in) throws IOException,ClassNotFoundException{
-       previousItem = in.readLong();
-       nextItem = in.readLong();
-       referenceItem = in.readLong();
-        
-    }
+/**
+ * 
+ * Copyright 2005-2006 The Apache Software Foundation
+ * 
+ * Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with
+ * the License. You may obtain a copy of the License at
+ * 
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * 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.activemq.kaha.impl;
+
+import java.io.DataInput;
+import java.io.DataInputStream;
+import java.io.DataOutput;
+import java.io.DataOutputStream;
+import java.io.Externalizable;
+import java.io.IOException;
+import java.io.ObjectInput;
+import java.io.ObjectOutput;
+import org.apache.activemq.kaha.Marshaller;
+
+/**
+* A an Item with a relative postion and location to other Items in the Store
+* 
+* @version $Revision: 1.2 $
+*/
+public final class LocatableItem extends Item implements Externalizable{
+    
+  
+    private static final long serialVersionUID=-6888731361600185708L;
+    private long previousItem=POSITION_NOT_SET;
+    private long nextItem=POSITION_NOT_SET;
+    private long referenceItem=POSITION_NOT_SET;
+   
+
+    public LocatableItem(){}
+
+    public LocatableItem(long prev,long next,long objOffset) throws IOException{
+        this.previousItem=prev;
+        this.nextItem=next;
+        this.referenceItem=objOffset;
+    }
+
+
+    public void writePayload(Marshaller marshaller,Object object,DataOutputStream dataOut) throws IOException{
+        dataOut.writeLong(previousItem);
+        dataOut.writeLong(nextItem);
+        dataOut.writeLong(referenceItem);
+        super.writePayload(marshaller,object,dataOut);
+    }
+
+    public Object readPayload(Marshaller marshaller,DataInputStream dataIn) throws IOException{
+        previousItem=dataIn.readLong();
+        nextItem=dataIn.readLong();
+        referenceItem=dataIn.readLong();
+        return super.readPayload(marshaller, dataIn);
+    }
+    
+    void readLocation(DataInput dataIn) throws IOException{
+        previousItem=dataIn.readLong();
+        nextItem=dataIn.readLong();
+        referenceItem=dataIn.readLong();
+    }
+
+    public void writeLocation(DataOutput dataOut) throws IOException{
+        dataOut.writeLong(previousItem);
+        dataOut.writeLong(nextItem);
+    }
+
+    public void setPreviousItem(long newPrevEntry){
+        previousItem=newPrevEntry;
+    }
+
+    public long getPreviousItem(){
+        return previousItem;
+    }
+
+    public void setNextItem(long newNextEntry){
+        nextItem=newNextEntry;
+    }
+
+    public long getNextItem(){
+        return nextItem;
+    }
+
+    public void setReferenceItem(long newObjectOffset){
+        referenceItem=newObjectOffset;
+    }
+
+    public long getReferenceItem(){
+        return referenceItem;
+    }
+
+    /* (non-Javadoc)
+     * @see org.apache.activemq.kaha.impl.Item#toString()
+     */
+    public String toString(){
+        String result=super.toString();
+        result+=" , referenceItem = "+referenceItem+", previousItem = "+previousItem+" , nextItem = "+nextItem;
+        return result;
+    }
+
+    /* (non-Javadoc)
+     * @see java.io.Externalizable#writeExternal(java.io.ObjectOutput)
+     */
+    public void writeExternal(ObjectOutput out) throws IOException{
+        out.writeLong(previousItem);
+        out.writeLong(nextItem);
+        out.writeLong(referenceItem);
+        
+    }
+
+    /* (non-Javadoc)
+     * @see java.io.Externalizable#readExternal(java.io.ObjectInput)
+     */
+    public void readExternal(ObjectInput in) throws IOException,ClassNotFoundException{
+       previousItem = in.readLong();
+       nextItem = in.readLong();
+       referenceItem = in.readLong();
+        
+    }
 }

Propchange: incubator/activemq/trunk/activemq-core/src/main/java/org/apache/activemq/kaha/impl/LocatableItem.java
------------------------------------------------------------------------------
    svn:eol-style = native