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@1071259 13f79535-47bb-0310-9956-ffa450edef68
This commit is contained in:
Hiram R. Chirino 2011-02-16 14:08:48 +00:00
parent 0bbc0acb84
commit b0c2a40fb9
1109 changed files with 1109 additions and 1110 deletions

View File

@ -24,7 +24,7 @@ import org.apache.camel.CamelContext;
import org.apache.camel.CamelContextAware;
/**
* @version $Revision: $
*
*/
public class CamelConnection extends ActiveMQConnection implements CamelContextAware {

View File

@ -26,7 +26,7 @@ import org.apache.camel.CamelContextAware;
* A JMS ConnectionFactory which resolves non-JMS destinations or instances of
* {@link CamelDestination} to use the {@link CamelContext} to perform smart routing etc
*
* @version $Revision: $
*
*/
public class CamelConnectionFactory extends ActiveMQConnectionFactory implements CamelContextAware {
private CamelContext camelContext;

View File

@ -34,7 +34,7 @@ import org.apache.camel.component.jms.JmsBinding;
import org.apache.camel.component.jms.JmsEndpoint;
/**
* @version $Revision: $
*
*/
public class CamelDestination implements CustomDestination, CamelContextAware {
private String uri;

View File

@ -34,7 +34,7 @@ import org.apache.camel.Processor;
* A JMS {@link javax.jms.MessageConsumer} which consumes message exchanges from
* a Camel {@link Endpoint}
*
* @version $Revision: $
*
*/
public class CamelMessageConsumer implements MessageConsumer {
private final CamelDestination destination;

View File

@ -35,7 +35,7 @@ import org.apache.camel.util.ObjectHelper;
* A JMS {@link javax.jms.MessageProducer} which sends message exchanges to a
* Camel {@link Endpoint}
*
* @version $Revision: $
*
*/
public class CamelMessageProducer extends ActiveMQMessageProducerSupport {

View File

@ -26,7 +26,7 @@ import org.apache.activemq.ActiveMQSession;
/**
* A JMS {@link Queue} object which refers to a Camel endpoint
*
* @version $Revision: $
*
*/
public class CamelQueue extends CamelDestination implements Queue {

View File

@ -27,7 +27,7 @@ import org.apache.camel.Endpoint;
* A JMS {@link javax.jms.QueueReceiver} which consumes message exchanges from a
* Camel {@link org.apache.camel.Endpoint}
*
* @version $Revision: $
*
*/
public class CamelQueueReceiver extends CamelMessageConsumer implements QueueReceiver {

View File

@ -28,7 +28,7 @@ import org.apache.camel.Endpoint;
* A JMS {@link javax.jms.QueueSender} which sends message exchanges to a Camel
* {@link org.apache.camel.Endpoint}
*
* @version $Revision: $
*
*/
public class CamelQueueSender extends CamelMessageProducer implements QueueSender {

View File

@ -26,7 +26,7 @@ import org.apache.activemq.ActiveMQSession;
/**
* A JMS {@link javax.jms.Topic} object which refers to a Camel endpoint
*
* @version $Revision: $
*
*/
public class CamelTopic extends CamelDestination implements Topic {

View File

@ -28,7 +28,7 @@ import org.apache.camel.Endpoint;
* A JMS {@link javax.jms.TopicPublisher} which sends message exchanges to a
* Camel {@link Endpoint}
*
* @version $Revision: $
*
*/
public class CamelTopicPublisher extends CamelMessageProducer implements TopicPublisher {

View File

@ -27,7 +27,7 @@ import org.apache.camel.Endpoint;
* A JMS {@link javax.jms.TopicSubscriber} which consumes message exchanges from a
* Camel {@link Endpoint}
*
* @version $Revision: $
*
*/
public class CamelTopicSubscriber extends CamelMessageConsumer implements TopicSubscriber {

View File

@ -43,7 +43,7 @@ import org.slf4j.LoggerFactory;
/**
* A helper bean which populates a {@link CamelContext} with ActiveMQ Queue endpoints
*
* @version $Revision: 1.1 $
*
* @org.apache.xbean.XBean
*/
public class CamelEndpointLoader implements CamelContextAware {

View File

@ -33,7 +33,7 @@ import org.apache.camel.util.jndi.JndiContext;
/**
* A helper class for test cases which use an embedded broker and use Camel to do the routing
*
* @version $Revision: 1.1 $
*
*/
public abstract class CamelEmbeddedBrokerTestSupport extends EmbeddedBrokerTestSupport {
protected CamelContext camelContext;

View File

@ -37,7 +37,7 @@ import org.slf4j.LoggerFactory;
import org.springframework.context.support.ClassPathXmlApplicationContext;
/**
* @version $Revision: $
*
*/
public class CamelJmsTest extends SpringTestSupport {

View File

@ -22,7 +22,7 @@ import org.apache.camel.Processor;
import org.apache.camel.Message;
/**
* @version $Revision: 1.1 $
*
*/
public class SetGroupIdProcessor implements Processor {
public void process(Exchange exchange) throws Exception {

View File

@ -31,7 +31,7 @@ import org.springframework.test.context.junit38.AbstractJUnit38SpringContextTest
import org.springframework.beans.factory.annotation.Autowired;
/**
* @version $Revision: 1.1 $
*
*/
@ContextConfiguration
public class SetHeaderTest extends AbstractJUnit38SpringContextTests {

View File

@ -25,7 +25,7 @@ import org.apache.camel.ContextTestSupport;
import org.apache.camel.builder.RouteBuilder;
/**
* @version $Revision: 1.1 $
*
*/
public class InvokeJmsMessageListenerTest extends ContextTestSupport {
protected MyMessageListener messageListener = new MyMessageListener();

View File

@ -30,7 +30,7 @@ import org.apache.activemq.console.formatter.CommandShellOutputFormatter;
/**
* A default implementation of the @{link CommandHandler} interface
*
* @version $Revision: $
*
*/
public class ConsoleCommandHandler implements CommandHandler {

View File

@ -41,7 +41,7 @@ import java.util.StringTokenizer;
* Main class that can bootstrap an ActiveMQ broker console. Handles command
* line argument parsing to set up and run broker tasks.
*
* @version $Revision$
*
*/
public class Main {

View File

@ -53,7 +53,7 @@ import org.apache.activemq.util.URISupport.CompositeData;
* TopicConnectionFactory. You can use this connection to create both
* QueueConnections and TopicConnections.
*
* @version $Revision: 1.9 $
*
* @see javax.jms.ConnectionFactory
*/
public class ActiveMQConnectionFactory extends JNDIBaseStorable implements ConnectionFactory, QueueConnectionFactory, TopicConnectionFactory, StatsCapable, Cloneable {

View File

@ -39,7 +39,7 @@ import org.apache.activemq.util.IntrospectionSupport;
import org.apache.activemq.util.JMSExceptionSupport;
/**
* @version $Revision$
*
*/
public class ActiveMQInputStream extends InputStream implements ActiveMQDispatcher {

View File

@ -21,7 +21,7 @@ import org.apache.activemq.command.MessageId;
/**
* Provides basic audit functions for Messages
*
* @version $Revision: 1.1.1.1 $
*
*/
public class ActiveMQMessageAudit extends ActiveMQMessageAuditNoSync {

View File

@ -92,7 +92,7 @@ import org.slf4j.LoggerFactory;
* It is a client programming error for a <CODE>MessageListener</CODE> to
* throw an exception.
*
* @version $Revision: 1.22 $
*
* @see javax.jms.MessageConsumer
* @see javax.jms.QueueReceiver
* @see javax.jms.TopicSubscriber

View File

@ -61,7 +61,7 @@ import org.apache.activemq.util.IntrospectionSupport;
* A JMS provider should do its best to expire messages accurately; however, the
* JMS API does not define the accuracy provided.
*
* @version $Revision: 1.14 $
*
* @see javax.jms.TopicPublisher
* @see javax.jms.QueueSender
* @see javax.jms.Session#createProducer

View File

@ -26,7 +26,7 @@ import javax.jms.MessageProducer;
/**
* A useful base class for implementing a {@link MessageProducer}
*
* @version $Revision: $
*
*/
public abstract class ActiveMQMessageProducerSupport implements MessageProducer, Closeable {
protected ActiveMQSession session;

View File

@ -52,7 +52,7 @@ import org.apache.activemq.command.ActiveMQTopic;
* A helper class for converting normal JMS interfaces into ActiveMQ specific
* ones.
*
* @version $Revision: 1.1 $
*
*/
public final class ActiveMQMessageTransformation {

View File

@ -34,7 +34,7 @@ import org.apache.activemq.command.ProducerInfo;
import org.apache.activemq.util.IOExceptionSupport;
/**
* @version $Revision$
*
*/
public class ActiveMQOutputStream extends OutputStream implements Disposable {

View File

@ -24,7 +24,7 @@ import org.slf4j.LoggerFactory;
* Defines the prefetch message policies for different types of consumers
*
* @org.apache.xbean.XBean element="prefetchPolicy"
* @version $Revision: 1.3 $
*
*/
public class ActiveMQPrefetchPolicy extends Object implements Serializable {
public static final int MAX_PREFETCH_SIZE = Short.MAX_VALUE - 1;

View File

@ -48,7 +48,7 @@ import javax.jms.TopicSubscriber;
* Sessions methods but the spec states that Queue session should throw
* Exceptions if topic operations are attempted on it.
*
* @version $Revision: 1.2 $
*
*/
public class ActiveMQQueueSession implements QueueSession {

View File

@ -173,7 +173,7 @@ import org.slf4j.LoggerFactory;
* Support for JTA in the JMS API is targeted at systems vendors who will be
* integrating the JMS API into their application server products.
*
* @version $Revision: 1.34 $
*
* @see javax.jms.Session
* @see javax.jms.QueueSession
* @see javax.jms.TopicSession

View File

@ -31,7 +31,7 @@ import org.slf4j.LoggerFactory;
* A utility class used by the Session for dispatching messages asynchronously
* to consumers
*
* @version $Revision$
*
* @see javax.jms.Session
*/
public class ActiveMQSessionExecutor implements Task {

View File

@ -47,7 +47,7 @@ import javax.jms.TopicSubscriber;
* Sessions methods but the spec states that TopicSession should throw
* Exceptions if queue operations are attempted on it.
*
* @version $Revision: 1.2 $
*
*/
public class ActiveMQTopicSession implements TopicSession {

View File

@ -39,7 +39,7 @@ import org.apache.activemq.util.IdGenerator;
* to use the transactional support available in their environment, rather
* than use these XA interfaces directly.
*
* @version $Revision: 1.6 $
*
* @see javax.jms.Connection
* @see javax.jms.ConnectionFactory
* @see javax.jms.QueueConnection

View File

@ -56,7 +56,7 @@ import org.apache.activemq.command.SessionId;
* to use the transactional support available in their environment, rather
* than use these XA interfaces directly.
*
* @version $Revision: 1.5 $
*
* @see javax.jms.Session
* @see javax.jms.QueueSession
* @see javax.jms.TopicSession

View File

@ -22,7 +22,7 @@ import javax.jms.JMSException;
* An exception which is closed if you try to access a resource which has already
* been closed
*
* @version $Revision: 1.2 $
*
*/
public class AlreadyClosedException extends JMSException {

View File

@ -27,7 +27,7 @@ import javax.jms.JMSException;
* Represents a message which has a typically out of band Binary Large Object
* (BLOB)
*
* @version $Revision: $
*
*/
public interface BlobMessage extends Message {

View File

@ -23,7 +23,7 @@ import javax.jms.JMSException;
* that provide a close() method. Useful for when you want to collect a
* heterogeous set of JMS object in a collection to be closed at a later time.
*
* @version $Revision: 1.2 $
*
*/
public interface Closeable {

View File

@ -21,7 +21,7 @@ import javax.jms.JMSException;
/**
* An exception thrown when a service is not correctly configured
*
* @version $Revision: 1.2 $
*
*/
public class ConfigurationException extends JMSException {
private static final long serialVersionUID = 5639082552451065258L;

View File

@ -21,7 +21,7 @@ import javax.jms.IllegalStateException;
/**
* An exception thrown when attempt is made to use a connection when the connection has been closed.
*
* @version $Revision: 1.2 $
*
*/
public class ConnectionClosedException extends IllegalStateException {
private static final long serialVersionUID = -7681404582227153308L;

View File

@ -24,7 +24,7 @@ import javax.jms.JMSException;
* An exception thrown when the a connection failure is detected (peer might
* close the connection, or a keep alive times out, etc.)
*
* @version $Revision$
*
*/
public class ConnectionFailedException extends JMSException {

View File

@ -30,7 +30,7 @@ import javax.jms.TopicSubscriber;
* such as to support <a href="http://activemq.apache.org/camel/">Apache Camel</a>
* to create and manage endpoints
*
* @version $Revision: $
*
*/
public interface CustomDestination extends Destination {

View File

@ -18,7 +18,7 @@ package org.apache.activemq;
/**
* @version $Revision$
*
*/
public interface Disposable {

View File

@ -26,7 +26,7 @@ import org.apache.activemq.advisory.DestinationSource;
/**
* A set of enhanced APIs for a JMS provider
*
* @version $Revision: 1.1 $
*
*/
public interface EnhancedConnection extends TopicConnection, QueueConnection, Closeable {

View File

@ -18,7 +18,7 @@ package org.apache.activemq;
/**
* @version $Revision: 1.2 $
*
*/
public interface LocalTransactionEventListener {
void beginEvent();

View File

@ -19,7 +19,7 @@ package org.apache.activemq;
/**
* Represents the JMS extension methods in Apache ActiveMQ
*
* @version $Revision: $
*
*/
public interface Message extends javax.jms.Message {

View File

@ -23,7 +23,7 @@ import javax.jms.MessageConsumer;
* message is available for consumption using the receive*() methods
* which is useful in Ajax style subscription models.
*
* @version $Revision: 1.1 $
*
*/
public interface MessageAvailableConsumer extends MessageConsumer {

View File

@ -26,7 +26,7 @@ import javax.jms.MessageConsumer;
* Note that this notification just indicates a message is available for synchronous consumption,
* it does not actually consume the message.
*
* @version $Revision: 1.1 $
*
*/
public interface MessageAvailableListener {

View File

@ -22,7 +22,7 @@ import javax.jms.IllegalStateException;
* An exception thrown when an operation is invoked on a service
* which has not yet been started.
*
* @version $Revision: 1.2 $
*
*/
public class NotStartedException extends IllegalStateException {

View File

@ -24,7 +24,7 @@ import java.util.Random;
* are rolled back.
*
* @org.apache.xbean.XBean element="redeliveryPolicy"
* @version $Revision: 1.11 $
*
*/
public class RedeliveryPolicy implements Cloneable, Serializable {

View File

@ -25,7 +25,7 @@ package org.apache.activemq;
* {@link org.springframework.beans.factory.InitializingBean}
* and {@link org.springframework.beans.factory.DisposableBean}
*
* @version $Revision: 1.1 $
*
*/
public interface Service {

View File

@ -32,7 +32,7 @@ import javax.jms.Topic;
* best use case is to send and receive large amounts of data that would be to
* large to hold in a single JMS message.
*
* @version $Revision$
*
*/
public interface StreamConnection extends Connection {

View File

@ -20,7 +20,7 @@ package org.apache.activemq;
/**
* A holder for different thread priorites used in ActiveMQ
*
* @version $Revision: 1.9 $
*
*/
public interface ThreadPriorities {

View File

@ -57,7 +57,7 @@ import org.slf4j.LoggerFactory;
* This could be done by using the services of a database that supports XA, or a
* JMS provider may choose to implement this functionality from scratch. <p/>
*
* @version $Revision: 1.10 $
*
* @see javax.jms.Session
* @see javax.jms.QueueSession
* @see javax.jms.TopicSession

View File

@ -41,7 +41,7 @@ import org.slf4j.LoggerFactory;
* This broker filter handles tracking the state of the broker for purposes of
* publishing advisory messages to advisory consumers.
*
* @version $Revision$
*
*/
public class AdvisoryBroker extends BrokerFilter {

View File

@ -24,7 +24,7 @@ import java.net.URL;
* The policy for configuring how BLOBs (Binary Large OBjects) are transferred
* out of band between producers, brokers and consumers.
*
* @version $Revision: $
*
*/
public class BlobTransferPolicy {
private String defaultUploadUrl = "http://localhost:8080/uploads/";

View File

@ -28,7 +28,7 @@ import org.apache.activemq.command.ActiveMQBlobMessage;
/**
* Represents a strategy of uploading a file/stream to some remote
*
* @version $Revision: $
*
*/
public interface BlobUploadStrategy {

View File

@ -28,7 +28,7 @@ import org.apache.activemq.command.ActiveMQBlobMessage;
/**
* A helper class to represent a required upload of a BLOB to some remote URL
*
* @version $Revision: $
*
*/
public class BlobUploader {

View File

@ -42,7 +42,7 @@ import org.apache.activemq.usage.Usage;
* The Message Broker which routes messages, maintains subscriptions and
* connections, acknowledges messages and handles transactions.
*
* @version $Revision: 1.8 $
*
*/
public interface Broker extends Region, Service {

View File

@ -34,7 +34,7 @@ import org.apache.activemq.command.TransactionId;
/**
* Used to add listeners for Broker actions
*
* @version $Revision: 1.10 $
*
*/
public class BrokerBroadcaster extends BrokerFilter {
protected volatile Broker[] listeners = new Broker[0];

View File

@ -27,7 +27,7 @@ import org.apache.activemq.util.IOExceptionSupport;
* list of currently supported URI syntaxes is described <a
* href="http://activemq.apache.org/how-do-i-embed-a-broker-inside-a-connection.html">here</a>
*
* @version $Revision$
*
*/
public final class BrokerFactory {

View File

@ -49,7 +49,7 @@ import org.apache.activemq.usage.Usage;
* Allows you to intercept broker operation so that features such as security
* can be implemented as a pluggable filter.
*
* @version $Revision: 1.10 $
*
*/
public class BrokerFilter implements Broker {

View File

@ -24,7 +24,7 @@ import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
/**
* @version $Revision: 1.3 $
*
*/
public class BrokerRegistry {

View File

@ -99,7 +99,7 @@ import org.slf4j.LoggerFactory;
* number of transport connectors, network connectors and a bunch of properties
* which can be used to configure the broker as its lazily created.
*
* @version $Revision: 1.1 $
*
* @org.apache.xbean.XBean
*/
public class BrokerService implements Service {

View File

@ -20,7 +20,7 @@ package org.apache.activemq.broker;
* An interface used to represent a component that wants the {@link BrokerService}
* to be injected
*
* @version $Revision: $
*
*/
public interface BrokerServiceAware {

View File

@ -30,7 +30,7 @@ import org.apache.activemq.command.ProducerInfo;
* the client has to expect many more messages to be dispatched than the
* pre-fetch setting allows.
*
* @version $Revision: 1.8 $
*
*/
public class CompositeDestinationBroker extends BrokerFilter {

View File

@ -24,7 +24,7 @@ import org.apache.activemq.command.ConnectionControl;
import org.apache.activemq.command.Response;
/**
* @version $Revision: 1.5 $
*
*/
public interface Connection extends Service {

View File

@ -33,7 +33,7 @@ import org.apache.activemq.transaction.Transaction;
/**
* Used to hold context information needed to process requests sent to a broker.
*
* @version $Revision: 1.5 $
*
*/
public class ConnectionContext {

View File

@ -23,7 +23,7 @@ import org.apache.activemq.command.BrokerInfo;
/**
* A connector creates and manages client connections that talk to the Broker.
*
* @version $Revision: 1.3 $
*
*/
public interface Connector extends Service {

View File

@ -23,7 +23,7 @@ import org.apache.activemq.broker.region.Subscription;
/**
* Holds internal state in the broker for a essageConsumer
*
* @version $Revision: 1.8 $
*
*/
public class ConsumerBrokerExchange {

View File

@ -29,7 +29,7 @@ import org.apache.activemq.util.URISupport.CompositeData;
* configuration parameters for the broker service. This directly configures the
* pojo model so there is no dependency on spring for configuration.
*
* @version $Revision$
*
*/
public class DefaultBrokerFactory implements BrokerFactoryHandler {

View File

@ -48,7 +48,7 @@ import org.apache.activemq.usage.Usage;
/**
* Dumb implementation - used to be overriden by listeners
*
* @version $Revision$
*
*/
public class EmptyBroker implements Broker {

View File

@ -49,7 +49,7 @@ import org.apache.activemq.usage.Usage;
* Implementation of the broker where all it's methods throw an
* BrokerStoppedException.
*
* @version $Revision$
*
*/
public class ErrorBroker implements Broker {

View File

@ -19,7 +19,7 @@ package org.apache.activemq.broker;
/**
* Inserts itself into the BrokerStack
*
* @version $Revision: 1.10 $
*
*/
public class InsertableMutableBrokerFilter extends MutableBrokerFilter {

View File

@ -28,7 +28,7 @@ import org.apache.activemq.command.ProducerId;
import org.apache.activemq.command.SessionId;
/**
* @version $Revision: 1.8 $
*
*/
public class MapTransportConnectionStateRegister implements TransportConnectionStateRegister{

View File

@ -50,7 +50,7 @@ import org.apache.activemq.usage.Usage;
* has more overhead than a BrokerFilter since access to the getNext().broker
* has to synchronized since it is mutable
*
* @version $Revision: 1.10 $
*
*/
public class MutableBrokerFilter implements Broker {

View File

@ -26,7 +26,7 @@ import org.slf4j.LoggerFactory;
/**
* Holds internal state in the broker for a MessageProducer
*
* @version $Revision: 1.8 $
*
*/
public class ProducerBrokerExchange {

View File

@ -29,7 +29,7 @@ import org.apache.activemq.command.ProducerId;
import org.apache.activemq.command.SessionId;
/**
* @version $Revision: 1.8 $
*
*/
public class SingleTransportConnectionStateRegister implements TransportConnectionStateRegister{

View File

@ -47,7 +47,7 @@ import org.slf4j.LoggerFactory;
* This broker filter handles the transaction related operations in the Broker
* interface.
*
* @version $Revision: 1.10 $
*
*/
public class TransactionBroker extends BrokerFilter {

View File

@ -99,7 +99,7 @@ import org.slf4j.LoggerFactory;
import static org.apache.activemq.thread.DefaultThreadPools.getDefaultTaskRunnerFactory;
/**
* @version $Revision: 1.8 $
*
*/
public class TransportConnection implements Connection, Task, CommandVisitor {
private static final Logger LOG = LoggerFactory.getLogger(TransportConnection.class);

View File

@ -21,7 +21,7 @@ import java.util.concurrent.atomic.AtomicInteger;
import org.apache.activemq.command.ConnectionInfo;
/**
* @version $Revision: 1.8 $
*
*/
public class TransportConnectionState extends org.apache.activemq.state.ConnectionState {

View File

@ -25,7 +25,7 @@ import org.apache.activemq.command.ProducerId;
import org.apache.activemq.command.SessionId;
/**
* @version $Revision: 1.8 $
*
*/
public interface TransportConnectionStateRegister{

View File

@ -45,7 +45,7 @@ import org.slf4j.LoggerFactory;
/**
* @org.apache.xbean.XBean
* @version $Revision: 1.6 $
*
*/
public class TransportConnector implements Connector, BrokerServiceAware {

View File

@ -29,7 +29,7 @@ import org.slf4j.LoggerFactory;
/**
* Used to provide information on the status of the Connection
*
* @version $Revision: 1.5 $
*
*/
public class TransportStatusDetector implements Service, Runnable {
private static final Logger LOG = LoggerFactory.getLogger(TransportStatusDetector.class);

View File

@ -24,7 +24,7 @@ import org.apache.activemq.command.Message;
* Note that you cannot trust the client, especially if working over the internet
* as they can spoof headers to be anything they like.
*
* @version $Revision: 1.8 $
*
*/
public class UserIDBroker extends BrokerFilter {

View File

@ -34,7 +34,7 @@ import org.slf4j.LoggerFactory;
* broker isn't aware they've gone. Can occur with network glitches or client
* error
*
* @version $Revision$
*
*/
public class ConnectionSplitBroker extends BrokerFilter{
private static final Logger LOG = LoggerFactory.getLogger(ConnectionSplitBroker.class);

View File

@ -54,7 +54,7 @@ import org.slf4j.LoggerFactory;
/**
* The Message Broker which passes messages to a slave
*
* @version $Revision: 1.8 $
*
*/
public class MasterBroker extends InsertableMutableBrokerFilter {

View File

@ -52,7 +52,7 @@ import org.slf4j.LoggerFactory;
* Availability of messages.
*
* @org.apache.xbean.XBean
* @version $Revision$
*
*/
public class MasterConnector implements Service, BrokerServiceAware {

View File

@ -39,7 +39,7 @@ import org.apache.activemq.network.NetworkConnector;
import org.apache.activemq.util.BrokerSupport;
/**
* @version $Revision$
*
*/
public class BrokerView implements BrokerViewMBean {

View File

@ -22,7 +22,7 @@ import org.apache.activemq.Service;
/**
* @author David Martin Clavo david(dot)martin(dot)clavo(at)gmail.com (for the reloadLog4jProperties method)
* @version $Revision$
*
*/
public interface BrokerViewMBean extends Service {

View File

@ -18,7 +18,7 @@
package org.apache.activemq.broker.jmx;
/**
* @version $Revision: 1.1 $
*
*/
public interface CompositeDataConstants {
String PROPERTIES = "PropertiesText";

View File

@ -24,7 +24,7 @@ import java.util.HashMap;
import java.util.Map;
/**
* @version $Revision: 1.1 $
*
*/
public class CompositeDataHelper {

View File

@ -26,7 +26,7 @@ import org.apache.activemq.broker.region.Subscription;
import org.apache.activemq.command.RemoveSubscriptionInfo;
/**
* @version $Revision: 1.5 $
*
*/
public class DurableSubscriptionView extends SubscriptionView implements DurableSubscriptionViewMBean {

View File

@ -21,7 +21,7 @@ import javax.management.openmbean.OpenDataException;
import javax.management.openmbean.TabularData;
/**
* @version $Revision: 1.5 $
*
*/
public interface DurableSubscriptionViewMBean extends SubscriptionViewMBean {
/**

View File

@ -26,7 +26,7 @@ import org.apache.activemq.command.SubscriptionInfo;
/**
*
* @version $Revision: 1.5 $
*
*/
public class InactiveDurableSubscriptionView extends DurableSubscriptionView implements DurableSubscriptionViewMBean {
protected SubscriptionInfo subscriptionInfo;

View File

@ -34,7 +34,7 @@ import javax.management.ObjectName;
/**
* A managed transport connection
*
* @version $Revision: 1.1 $
*
*/
public class ManagedTransportConnection extends TransportConnection {
private static final Logger LOG = LoggerFactory.getLogger(ManagedTransportConnection.class);

View File

@ -29,7 +29,7 @@ import javax.management.ObjectName;
* A managed transport connector which can create multiple managed connections
* as clients connect.
*
* @version $Revision: 1.1 $
*
*/
public class ManagedTransportConnector extends TransportConnector {

View File

@ -39,7 +39,7 @@ import java.util.concurrent.atomic.AtomicBoolean;
* An abstraction over JMX mbean registration
*
* @org.apache.xbean.XBean
* @version $Revision$
*
*/
public class ManagementContext implements Service {
/**

View File

@ -26,7 +26,7 @@ import org.apache.activemq.command.ActiveMQTopic;
import org.apache.activemq.filter.DestinationFilter;
/**
* @version $Revision: 1.5 $
*
*/
public class SubscriptionView implements SubscriptionViewMBean {

View File

@ -19,7 +19,7 @@ package org.apache.activemq.broker.jmx;
import javax.jms.InvalidSelectorException;
/**
* @version $Revision: 1.5 $
*
*/
public interface SubscriptionViewMBean {

View File

@ -48,7 +48,7 @@ import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
/**
* @version $Revision: 1.14 $
*
*/
public abstract class AbstractRegion implements Region {

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