Removing svn keywords, they don't have much value and just add additional noise when diffing source trees.

git-svn-id: https://svn.apache.org/repos/asf/activemq/trunk@1071256 13f79535-47bb-0310-9956-ffa450edef68
This commit is contained in:
Hiram R. Chirino 2011-02-16 13:58:54 +00:00
parent 8280417876
commit 0bbc0acb84
718 changed files with 719 additions and 719 deletions

View File

@ -28,7 +28,7 @@ import org.springframework.jms.connection.SingleConnectionFactory;
/**
* The <a href="http://activemq.apache.org/camel/activemq.html">ActiveMQ Component</a>
*
* @version $Revision$
*
*/
public class ActiveMQComponent extends JmsComponent {
private final CopyOnWriteArrayList<SingleConnectionFactory> singleConnectionFactoryList =

View File

@ -29,7 +29,7 @@ import org.springframework.jms.core.JmsTemplate;
import org.springframework.transaction.PlatformTransactionManager;
/**
* @version $Revision$
*
*/
public class ActiveMQConfiguration extends JmsConfiguration {
private String brokerURL = ActiveMQConnectionFactory.DEFAULT_BROKER_URL;

View File

@ -26,7 +26,7 @@ import java.util.Map;
/**
* The <a href="http://camel.apache.org/activemq-journal.html">ActiveMQ Journal Component</a>
*
* @version $Revision$
*
*/
public class JournalComponent extends DefaultComponent {

View File

@ -21,7 +21,7 @@ import org.apache.activemq.command.ActiveMQDestination;
import org.apache.camel.Converter;
/**
* @version $Revision$
*
*/
@Converter
public class ActiveMQConverter {

View File

@ -33,7 +33,7 @@ import org.apache.camel.component.jms.JmsBinding;
import org.apache.camel.component.jms.JmsEndpoint;
/**
* @version $Revision$
*
*/
@Converter
public class ActiveMQMessageConverter {

View File

@ -34,7 +34,7 @@ import org.springframework.test.context.ContextConfiguration;
import org.springframework.test.context.junit38.AbstractJUnit38SpringContextTests;
/**
* @version $Revision$
*
*/
@ContextConfiguration
public class CamelRedeliveryTest extends AbstractJUnit38SpringContextTests {

View File

@ -29,7 +29,7 @@ import org.springframework.jms.listener.AbstractMessageListenerContainer;
import org.springframework.jms.connection.SingleConnectionFactory;
/**
* @version $Revision$
*
*/
public class ActiveMQConfigureTest extends ContextTestSupport {

View File

@ -37,7 +37,7 @@ import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
/**
* @version $Revision$
*
*/
public class ActiveMQJmsHeaderRouteTest extends ContextTestSupport {
private static final transient Logger LOG = LoggerFactory.getLogger(ActiveMQJmsHeaderRouteTest.class);

View File

@ -36,7 +36,7 @@ import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
/**
* @version $Revision$
*
*/
public class ActiveMQReplyToHeaderUsingConverterTest extends ContextTestSupport {
private static final transient Logger LOG = LoggerFactory.getLogger(ActiveMQReplyToHeaderUsingConverterTest.class);

View File

@ -25,7 +25,7 @@ import org.apache.camel.component.jms.JmsEndpoint;
import org.apache.camel.component.mock.MockEndpoint;
/**
* @version $Revision$
*
*/
public class ActiveMQRouteTest extends ContextTestSupport {
protected MockEndpoint resultEndpoint;

View File

@ -32,7 +32,7 @@ import org.apache.camel.component.mock.MockEndpoint;
import org.apache.camel.component.jms.JmsMessage;
/**
* @version $Revision$
*
*/
public class AdvisoryConsumerExample extends ContextTestSupport {

View File

@ -37,7 +37,7 @@ import org.slf4j.LoggerFactory;
* Shows that we can see the queues inside ActiveMQ via Camel
* by enabling the {@link ActiveMQComponent#setExposeAllQueues(boolean)} flag
*
* @version $Revision$
*
*/
public class AutoExposeQueuesInCamelTest extends EmbeddedBrokerTestSupport {
private static final transient Logger LOG = LoggerFactory.getLogger(AutoExposeQueuesInCamelTest.class);

View File

@ -43,7 +43,7 @@ import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
/**
* @version $Revision$
*
*/
public class InvokeRequestReplyUsingJmsReplyToHeaderTest extends ContextTestSupport {
private static final transient Logger LOG = LoggerFactory.getLogger(ActiveMQReplyToHeaderUsingConverterTest.class);

View File

@ -22,7 +22,7 @@ import org.apache.camel.ContextTestSupport;
import org.apache.camel.Endpoint;
/**
* @version $Revision$
*
*/
public class JournalConfigureTest extends ContextTestSupport {

View File

@ -28,7 +28,7 @@ import org.apache.camel.builder.RouteBuilder;
* Used to get an idea of what kind of performance can be expected from
* the journal.
*
* @version $Revision$
*
*/
public class JournalRoutePerformance extends ContextTestSupport {

View File

@ -28,7 +28,7 @@ import org.apache.camel.component.mock.MockEndpoint;
import org.apache.camel.impl.DefaultCamelContext;
/**
* @version $Revision$
*
*/
public class JournalRouteTest extends ContextTestSupport {

View File

@ -29,7 +29,7 @@ import org.apache.camel.builder.RouteBuilder;
import org.apache.camel.component.mock.MockEndpoint;
/**
* @version $Revision$
*
*/
public class InvokeMessageListenerTest extends ContextTestSupport { protected MockEndpoint resultEndpoint;
protected String startEndpointUri = "activemq:queue:test.a";

View File

@ -25,7 +25,7 @@ import org.apache.activemq.broker.util.CommandMessageListener;
* A simple interactive console which can be used to communicate with a running
* broker assuming that the classpath is fully setup
*
* @version $Revision$
*
*/
public final class SimpleConsole {

View File

@ -31,7 +31,7 @@ import org.apache.activemq.util.LRUCache;
/**
* Provides basic audit functions for Messages without sync
*
* @version $Revision$
*
*/
public class ActiveMQMessageAuditNoSync implements Serializable {

View File

@ -32,7 +32,7 @@ import org.apache.activemq.transport.Transport;
/**
* A factory of {@link XAConnection} instances
*
* @version $Revision$
*
*/
public class ActiveMQXAConnectionFactory extends ActiveMQConnectionFactory implements XAConnectionFactory, XAQueueConnectionFactory, XATopicConnectionFactory {

View File

@ -26,7 +26,7 @@ import javax.jms.Session;
* A plugin strategy for transforming a message before it is sent by the JMS client or before it is
* dispatched to the JMS consumer
*
* @version $Revision$
*
*/
public interface MessageTransformer {

View File

@ -22,7 +22,7 @@ import javax.jms.Message;
/**
* A useful base class for message transformers.
*
* @version $Revision$
*
*/
public abstract class MessageTransformerSupport implements MessageTransformer {

View File

@ -25,7 +25,7 @@ import org.apache.activemq.command.ConsumerId;
/**
* An event when the number of consumers on a given destination changes.
*
* @version $Revision$
*
*/
public abstract class ConsumerEvent extends EventObject {
private static final long serialVersionUID = 2442156576867593780L;

View File

@ -41,7 +41,7 @@ import org.slf4j.LoggerFactory;
* An object which can be used to listen to the number of active consumers
* available on a given destination.
*
* @version $Revision$
*
*/
public class ConsumerEventSource implements Service, MessageListener {
private static final Logger LOG = LoggerFactory.getLogger(ConsumerEventSource.class);

View File

@ -19,7 +19,7 @@ package org.apache.activemq.advisory;
/**
* Listen to the changes in the number of active consumers available for a given destination.
*
* @version $Revision$
*
*/
public interface ConsumerListener {

View File

@ -22,7 +22,7 @@ import org.apache.activemq.command.ConsumerInfo;
/**
* An event when a new consumer has started.
*
* @version $Revision$
*
*/
public class ConsumerStartedEvent extends ConsumerEvent {

View File

@ -22,7 +22,7 @@ import org.apache.activemq.command.ConsumerId;
/**
* An event generated when a consumer stops.
*
* @version $Revision$
*
*/
public class ConsumerStoppedEvent extends ConsumerEvent {

View File

@ -27,7 +27,7 @@ import org.apache.activemq.command.ActiveMQDestination;
/**
* An event caused when a destination is created or deleted
*
* @version $Revision$
*
*/
public class DestinationEvent extends EventObject {
private static final long serialVersionUID = 2442156576867593780L;

View File

@ -19,7 +19,7 @@ package org.apache.activemq.advisory;
/**
* Listen to the changes in destinations being created or destroyed
*
* @version $Revision$
*
*/
public interface DestinationListener {
void onDestinationEvent(DestinationEvent event);

View File

@ -42,7 +42,7 @@ import org.slf4j.LoggerFactory;
* A helper class which keeps track of the Destinations available in a broker and allows you to listen to them
* being created or deleted.
*
* @version $Revision$
*
*/
public class DestinationSource implements MessageListener {
private static final Logger LOG = LoggerFactory.getLogger(ConsumerEventSource.class);

View File

@ -25,7 +25,7 @@ import org.apache.activemq.command.ProducerId;
/**
* An event when the number of producers on a given destination changes.
*
* @version $Revision: 359679 $
*
*/
public abstract class ProducerEvent extends EventObject {
private static final long serialVersionUID = 2442156576867593780L;

View File

@ -41,7 +41,7 @@ import org.slf4j.LoggerFactory;
* An object which can be used to listen to the number of active consumers
* available on a given destination.
*
* @version $Revision: 359679 $
*
*/
public class ProducerEventSource implements Service, MessageListener {
private static final Logger LOG = LoggerFactory.getLogger(ProducerEventSource.class);

View File

@ -19,7 +19,7 @@ package org.apache.activemq.advisory;
/**
* Listen to the changes in the number of active consumers available for a given destination.
*
* @version $Revision: 359679 $
*
*/
public interface ProducerListener {

View File

@ -22,7 +22,7 @@ import org.apache.activemq.command.ProducerInfo;
/**
* An event when a new consumer has started.
*
* @version $Revision: 359679 $
*
*/
public class ProducerStartedEvent extends ProducerEvent {

View File

@ -22,7 +22,7 @@ import org.apache.activemq.command.ProducerId;
/**
* An event generated when a consumer stops.
*
* @version $Revision: 359679 $
*
*/
public class ProducerStoppedEvent extends ProducerEvent {

View File

@ -21,7 +21,7 @@ import java.net.URI;
/**
* Represents the interface used to create a broker from a URI scheme.
*
* @version $Revision$
*
*/
public interface BrokerFactoryHandler {
BrokerService createBroker(URI brokerURI) throws Exception;

View File

@ -19,7 +19,7 @@ package org.apache.activemq.broker;
/**
* Represents a plugin into a Broker
*
* @version $Revision$
*
*/
public interface BrokerPlugin {

View File

@ -22,7 +22,7 @@ import org.slf4j.LoggerFactory;
/**
* A useful base class for implementing broker plugins.
*
* @version $Revision$
*
*/
public abstract class BrokerPluginSupport extends MutableBrokerFilter implements BrokerPlugin {
private static final Logger LOG = LoggerFactory.getLogger(BrokerPluginSupport.class);

View File

@ -23,7 +23,7 @@ import org.apache.activemq.command.ActiveMQDestination;
/**
* An exception thrown if a destination is attempted to be created when it already exists.
*
* @version $Revision$
*
*/
public class DestinationAlreadyExistsException extends JMSException {
private final ActiveMQDestination destination;

View File

@ -32,7 +32,7 @@ import org.apache.activemq.util.IntrospectionSupport;
* A {@link BrokerFactoryHandler} which uses a properties file to configure the
* broker's various policies.
*
* @version $Revision$
*
*/
public class PropertiesBrokerFactory implements BrokerFactoryHandler {

View File

@ -21,7 +21,7 @@ import org.apache.activemq.broker.region.TopicSubscription;
/**
*
* @version $Revision$
*
*/
public class TopicSubscriptionView extends SubscriptionView implements TopicSubscriptionViewMBean {

View File

@ -18,7 +18,7 @@ package org.apache.activemq.broker.jmx;
/**
*
* @version $Revision$
*
*/
public interface TopicSubscriptionViewMBean extends SubscriptionViewMBean {

View File

@ -19,7 +19,7 @@ package org.apache.activemq.broker.region;
/**
* Represents a Composite Pattern of a {@link DestinationInterceptor}
*
* @version $Revision$
*
*/
public class CompositeDestinationInterceptor implements DestinationInterceptor {

View File

@ -23,7 +23,7 @@ import org.apache.activemq.management.StatsImpl;
/**
* The J2EE Statistics for the Connection.
*
* @version $Revision$
*
*/
public class ConnectionStatistics extends StatsImpl {

View File

@ -24,7 +24,7 @@ import org.apache.activemq.management.StatsImpl;
/**
* The J2EE Statistics for the a Destination.
*
* @version $Revision$
*
*/
public class ConnectorStatistics extends StatsImpl {

View File

@ -28,7 +28,7 @@ import org.apache.activemq.command.SubscriptionInfo;
* Used to create Destinations. One instance of DestinationFactory is used per BrokerService.
*
* @author fateev@amazon.com
* @version $Revision$
*
*/
public abstract class DestinationFactory {

View File

@ -37,7 +37,7 @@ import org.apache.activemq.thread.TaskRunnerFactory;
* {@link org.apache.activemq.broker.region.Destination}.
*
* @author fateev@amazon.com
* @version $Revision$
*
*/
public class DestinationFactoryImpl extends DestinationFactory {

View File

@ -35,7 +35,7 @@ import org.apache.activemq.usage.Usage;
/**
*
* @version $Revision$
*
*/
public class DestinationFilter implements Destination {

View File

@ -20,7 +20,7 @@ package org.apache.activemq.broker.region;
/**
* Represents an interceptor on destination instances.
*
* @version $Revision$
*
*/
public interface DestinationInterceptor {

View File

@ -23,7 +23,7 @@ import org.apache.activemq.broker.ConnectionContext;
/**
* Represents a filter on message references
*
* @version $Revision$
*
*/
public interface MessageReferenceFilter {

View File

@ -20,7 +20,7 @@ package org.apache.activemq.broker.region;
* Queue specific MessageReference.
*
* @author fateev@amazon.com
* @version $Revision$
*
*/
public interface QueueMessageReference extends MessageReference {

View File

@ -34,7 +34,7 @@ import org.apache.activemq.usage.SystemUsage;
* Abstract method holder for pending message (messages awaiting disptach to a
* consumer) cursor
*
* @version $Revision$
*
*/
public abstract class AbstractPendingMessageCursor implements PendingMessageCursor {
protected int memoryUsageHighWaterMark = 70;

View File

@ -44,7 +44,7 @@ import org.apache.kahadb.util.ByteSequence;
* persist pending messages pending message (messages awaiting dispatch to a
* consumer) cursor
*
* @version $Revision$
*
*/
public class FilePendingMessageCursor extends AbstractPendingMessageCursor implements UsageListener {
static final Logger LOG = LoggerFactory.getLogger(FilePendingMessageCursor.class);

View File

@ -31,7 +31,7 @@ import org.apache.activemq.usage.SystemUsage;
* Interface to pending message (messages awaiting disptach to a consumer)
* cursor
*
* @version $Revision$
*
*/
public interface PendingMessageCursor extends Service {

View File

@ -28,7 +28,7 @@ import org.slf4j.LoggerFactory;
* persist pending messages pending message (messages awaiting dispatch to a
* consumer) cursor
*
* @version $Revision: 474985 $
*
*/
class QueueStorePrefetch extends AbstractStoreCursor {
private static final Logger LOG = LoggerFactory.getLogger(QueueStorePrefetch.class);

View File

@ -37,7 +37,7 @@ import org.slf4j.LoggerFactory;
* persist pending messages pending message (messages awaiting dispatch to a
* consumer) cursor
*
* @version $Revision$
*
*/
public class StoreDurableSubscriberCursor extends AbstractPendingMessageCursor {

View File

@ -27,7 +27,7 @@ import org.slf4j.LoggerFactory;
/**
* Store based Cursor for Queues
*
* @version $Revision: 474985 $
*
*/
public class StoreQueueCursor extends AbstractPendingMessageCursor {

View File

@ -30,7 +30,7 @@ import org.slf4j.LoggerFactory;
* persist pendingCount messages pendingCount message (messages awaiting disptach
* to a consumer) cursor
*
* @version $Revision$
*
*/
class TopicStorePrefetch extends AbstractStoreCursor {
private static final Logger LOG = LoggerFactory.getLogger(TopicStorePrefetch.class);

View File

@ -29,7 +29,7 @@ import org.apache.activemq.broker.region.QueueMessageReference;
* hold pending messages in a linked list (messages awaiting disptach to a
* consumer) cursor
*
* @version $Revision$
*
*/
public class VMPendingMessageCursor extends AbstractPendingMessageCursor {
private final PendingList list;

View File

@ -19,7 +19,7 @@ package org.apache.activemq.broker.region.group;
/**
* Represents an empty {@link MessageGroupSet}
*
* @version $Revision$
*
*/
public class EmptyMessageGroupSet implements MessageGroupSet {

View File

@ -21,7 +21,7 @@ import org.apache.activemq.command.ConsumerId;
/**
* Uses hash-code buckets to associate consumers with sets of message group IDs.
*
* @version $Revision$
*
*/
public class MessageGroupHashBucket implements MessageGroupMap {

View File

@ -24,7 +24,7 @@ package org.apache.activemq.broker.region.group;
*
* @org.apache.xbean.XBean
*
* @version $Revision$
*
*/
public class MessageGroupHashBucketFactory implements MessageGroupMapFactory {

View File

@ -21,7 +21,7 @@ import org.apache.activemq.command.ConsumerId;
/**
* Represents a map of JMSXGroupID values to consumer IDs
*
* @version $Revision$
*
*/
public interface MessageGroupMap {

View File

@ -20,7 +20,7 @@ package org.apache.activemq.broker.region.group;
* Represents a factory used to create new instances of {@link MessageGroupMap}
* for a destination.
*
* @version $Revision$
*
*/
public interface MessageGroupMapFactory {

View File

@ -19,7 +19,7 @@ package org.apache.activemq.broker.region.group;
/**
* Represents a set of Message Group IDs
*
* @version $Revision$
*
*/
public interface MessageGroupSet {

View File

@ -27,7 +27,7 @@ import org.apache.activemq.command.ConsumerId;
* which can become a memory leak if clients die before they complete a message
* group.
*
* @version $Revision$
*
*/
public class SimpleMessageGroupMap implements MessageGroupMap {
private Map<String, ConsumerId> map = new ConcurrentHashMap<String, ConsumerId>();

View File

@ -22,7 +22,7 @@ package org.apache.activemq.broker.region.group;
*
* @org.apache.xbean.XBean
*
* @version $Revision$
*
*/
public class SimpleMessageGroupMapFactory implements MessageGroupMapFactory {

View File

@ -22,7 +22,7 @@ import java.util.Set;
/**
* A simple implementation which just uses a {@link Set}
*
* @version $Revision$
*
*/
public class SimpleMessageGroupSet implements MessageGroupSet {

View File

@ -25,7 +25,7 @@ import org.slf4j.LoggerFactory;
* A strategy for choosing which destination is used for dead letter queue
* messages.
*
* @version $Revision: 426366 $
*
*/
public abstract class AbstractDeadLetterStrategy implements DeadLetterStrategy {
private static final Logger LOG = LoggerFactory.getLogger(AbstractDeadLetterStrategy.class);

View File

@ -23,7 +23,7 @@ import org.apache.activemq.broker.region.TopicSubscription;
*
* @org.apache.xbean.XBean
*
* @version $Revision$
*
*/
public class ConstantPendingMessageLimitStrategy implements PendingMessageLimitStrategy {

View File

@ -22,7 +22,7 @@ import org.apache.activemq.command.Message;
/**
* A strategy for choosing which destination is used for dead letter queue messages.
*
* @version $Revision$
*
*/
public interface DeadLetterStrategy {

View File

@ -25,7 +25,7 @@ import org.apache.activemq.command.ActiveMQTopic;
* DLQ using the subject naming hierarchy.
*
* @org.apache.xbean.XBean
* @version $Revision$
*
*/
public class IndividualDeadLetterStrategy extends AbstractDeadLetterStrategy {

View File

@ -24,7 +24,7 @@ import org.apache.activemq.broker.region.MessageReference;
/**
* A strategy for evicting messages from slow consumers.
*
* @version $Revision$
*
*/
public interface MessageEvictionStrategy {

View File

@ -19,7 +19,7 @@ package org.apache.activemq.broker.region.policy;
/**
* A useful base class for implementation inheritence.
*
* @version $Revision$
*
*/
public abstract class MessageEvictionStrategySupport implements MessageEvictionStrategy {

View File

@ -24,7 +24,7 @@ import org.apache.activemq.command.Message;
/**
* Represents some kind of query which will load initial messages from some source for a new topic subscriber.
*
* @version $Revision$
*
*/
public interface MessageQuery {

View File

@ -26,7 +26,7 @@ import org.apache.activemq.broker.region.MessageReference;
*
* @org.apache.xbean.XBean
*
* @version $Revision$
*
*/
public class OldestMessageEvictionStrategy extends MessageEvictionStrategySupport {

View File

@ -27,7 +27,7 @@ import org.apache.activemq.broker.region.MessageReference;
*
* @org.apache.xbean.XBean
*
* @version $Revision$messageEvictionStrategy
* messageEvictionStrategy
*/
public class OldestMessageWithLowestPriorityEvictionStrategy extends MessageEvictionStrategySupport {

View File

@ -26,7 +26,7 @@ import org.apache.activemq.broker.region.TopicSubscription;
* This allows us to keep dispatching messages to slow consumers while not blocking fast consumers
* and discarding the messages oldest first.
*
* @version $Revision$
*
*/
public interface PendingMessageLimitStrategy {

View File

@ -24,7 +24,7 @@ import org.apache.activemq.broker.region.TopicSubscription;
*
* @org.apache.xbean.XBean
*
* @version $Revision$
*
*/
public class PrefetchRatePendingMessageLimitStrategy implements PendingMessageLimitStrategy {

View File

@ -42,7 +42,7 @@ import org.slf4j.LoggerFactory;
* specific query mechanism to load any messages they may have missed.
*
* @org.apache.xbean.XBean
* @version $Revision$
*
*/
public class QueryBasedSubscriptionRecoveryPolicy implements SubscriptionRecoveryPolicy {

View File

@ -26,7 +26,7 @@ import org.apache.activemq.command.ActiveMQQueue;
*
* @org.apache.xbean.XBean
*
* @version $Revision$
*
*/
public class SharedDeadLetterStrategy extends AbstractDeadLetterStrategy {

View File

@ -22,7 +22,7 @@ import org.apache.activemq.broker.region.Destination;
/**
*
* @version $Revision$
*
*/
public abstract class CompositeDestination implements VirtualDestination {

View File

@ -31,7 +31,7 @@ import org.apache.activemq.filter.NonCachedMessageEvaluationContext;
* Represents a composite {@link Destination} where send()s are replicated to
* each Destination instance.
*
* @version $Revision$
*
*/
public class CompositeDestinationFilter extends DestinationFilter {

View File

@ -25,7 +25,7 @@ import org.apache.activemq.command.ActiveMQQueue;
*
* @org.apache.xbean.XBean
*
* @version $Revision$
*
*/
public class CompositeQueue extends CompositeDestination {

View File

@ -24,7 +24,7 @@ import org.apache.activemq.command.ActiveMQTopic;
*
* @org.apache.xbean.XBean
*
* @version $Revision$
*
*/
public class CompositeTopic extends CompositeDestination {

View File

@ -30,7 +30,7 @@ import org.apache.activemq.selector.SelectorParser;
*
* @org.apache.xbean.XBean
*
* @version $Revision$
*
*/
public class FilteredDestination {

View File

@ -32,7 +32,7 @@ import org.slf4j.LoggerFactory;
* Creates <a href="http://activemq.org/site/mirrored-queues.html">Mirrored
* Queue</a> using a prefix and postfix to define the topic name on which to mirror the queue to.
*
* @version $Revision$
*
* @org.apache.xbean.XBean
*/
public class MirroredQueue implements DestinationInterceptor, BrokerServiceAware {

View File

@ -23,7 +23,7 @@ import org.apache.activemq.command.ActiveMQDestination;
/**
* Represents some kind of virtual destination.
*
* @version $Revision$
*
*/
public interface VirtualDestination extends DestinationInterceptor {

View File

@ -33,7 +33,7 @@ import org.apache.activemq.filter.DestinationMap;
* href="http://activemq.apache.org/virtual-destinations.html">Virtual Topics</a>.
*
* @org.apache.xbean.XBean
* @version $Revision$
*
*/
public class VirtualDestinationInterceptor implements DestinationInterceptor {

View File

@ -28,7 +28,7 @@ import org.apache.activemq.command.ActiveMQTopic;
*
* @org.apache.xbean.XBean
*
* @version $Revision$
*
*/
public class VirtualTopic implements VirtualDestination {

View File

@ -27,7 +27,7 @@ import org.apache.activemq.command.Message;
* A Destination which implements <a
* href="http://activemq.org/site/virtual-destinations.html">Virtual Topic</a>
*
* @version $Revision$
*
*/
public class VirtualTopicInterceptor extends DestinationFilter {

View File

@ -35,7 +35,7 @@ import org.slf4j.LoggerFactory;
/**
* An agent which listens to commands on a JMS destination
*
* @version $Revision$
*
* @org.apache.xbean.XBean
*/
public class CommandAgent implements Service, ExceptionListener {

View File

@ -28,7 +28,7 @@ import java.net.URISyntaxException;
*
* @org.apache.xbean.XBean
*
* @version $Revision: 427613 $
*
*/
public class MulticastTraceBrokerPlugin extends UDPTraceBrokerPlugin {

View File

@ -63,7 +63,7 @@ import org.slf4j.LoggerFactory;
* socket.
*
* @org.apache.xbean.XBean element="udpTraceBrokerPlugin"
* @version $Revision: 427613 $
*
*/
public class UDPTraceBrokerPlugin extends BrokerPluginSupport {

View File

@ -19,7 +19,7 @@ package org.apache.activemq.command;
/**
* A default endpoint.
*
* @version $Revision$
*
*/
public class BaseEndpoint implements Endpoint {

View File

@ -23,7 +23,7 @@ package org.apache.activemq.command;
* for all commands. For transports like multicast there could be different
* endpoints being used on the same transport.
*
* @version $Revision$
*
*/
public interface Endpoint {

View File

@ -22,7 +22,7 @@ import org.apache.activemq.state.CommandVisitor;
* Represents the end marker of a stream of {@link PartialCommand} instances.
*
* @openwire:marshaller code="61"
* @version $Revision$
*
*/
public class LastPartialCommand extends PartialCommand {

View File

@ -23,7 +23,7 @@ import org.apache.activemq.state.CommandVisitor;
*
* @openwire:marshaller code="20"
*
* @version $Revision$
*
*/
public class MessagePull extends BaseCommand {

View File

@ -23,7 +23,7 @@ import org.apache.activemq.state.CommandVisitor;
* pieces.
*
* @openwire:marshaller code="60"
* @version $Revision$
*
*/
public class PartialCommand implements Command {

View File

@ -25,7 +25,7 @@ import org.apache.activemq.state.CommandVisitor;
* TCP/IP if a socket has been re-established.
*
* @openwire:marshaller code="65"
* @version $Revision$
*
*/
public class ReplayCommand extends BaseCommand {

Some files were not shown because too many files have changed in this diff Show More