ARTEMIS-3538: Removing // --------- comments from the codebase

This commit is contained in:
Asukwo-comfort 2021-11-02 23:18:48 +01:00 committed by Clebert Suconic
parent e41ec90a66
commit 923e4cc892
311 changed files with 74 additions and 1564 deletions

View File

@ -38,8 +38,6 @@ public final class SimpleString implements CharSequence, Serializable, Comparabl
private static final SimpleString EMPTY = new SimpleString("");
private static final long serialVersionUID = 4204223851422244307L;
// Attributes
// ------------------------------------------------------------------------
private final byte[] data;
private transient int hash;
@ -49,8 +47,6 @@ public final class SimpleString implements CharSequence, Serializable, Comparabl
private transient String[] paths;
// Static
// ----------------------------------------------------------------------
/**
* Returns a SimpleString constructed from the {@code string} parameter.
@ -74,8 +70,6 @@ public final class SimpleString implements CharSequence, Serializable, Comparabl
return pool.getOrCreate(string);
}
// Constructors
// ----------------------------------------------------------------------
/**
* creates a SimpleString from a conventional String

View File

@ -24,7 +24,7 @@ import org.apache.activemq.artemis.api.core.ActiveMQBuffers;
import org.apache.activemq.artemis.api.core.SimpleString;
public class RandomUtil {
// Constants -----------------------------------------------------
protected static final Random random = new Random();
@ -32,9 +32,6 @@ public class RandomUtil {
return random;
}
// Attributes ----------------------------------------------------
// Static --------------------------------------------------------
public static String randomString() {
return java.util.UUID.randomUUID().toString();
@ -131,7 +128,7 @@ public class RandomUtil {
return RandomUtil.random.nextFloat();
}
// Constructors --------------------------------------------------
// Public --------------------------------------------------------

View File

@ -25,17 +25,12 @@ import org.junit.Before;
import org.junit.Test;
public class ConcurrentHashSetTest extends Assert {
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
private ConcurrentSet<String> set;
private String element;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
// Public --------------------------------------------------------

View File

@ -25,9 +25,6 @@ import org.junit.Test;
public class TypedPropertiesConversionTest {
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
private TypedProperties props;
@ -35,10 +32,6 @@ public class TypedPropertiesConversionTest {
private final SimpleString unknownKey = new SimpleString("this.key.is.never.used");
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
// Public --------------------------------------------------------
@Before

View File

@ -56,7 +56,7 @@ public class TypedPropertiesTest {
}
}
// Constructors --------------------------------------------------
// Public --------------------------------------------------------

View File

@ -137,7 +137,6 @@ public final class AddressSettingsInfo {
private final boolean enableMetrics;
// Static --------------------------------------------------------
public static AddressSettingsInfo from(final String jsonString) {
JsonObject object = JsonUtil.readJsonObject(jsonString);
@ -200,7 +199,6 @@ public final class AddressSettingsInfo {
object.getBoolean("enableMetrics"));
}
// Constructors --------------------------------------------------
public AddressSettingsInfo(String addressFullMessagePolicy,
long maxSizeBytes,

View File

@ -34,7 +34,6 @@ public final class DayCounterInfo {
private final long[] counters;
// Static --------------------------------------------------------
public static String toJSON(final DayCounterInfo[] infos) {
JsonObjectBuilder json = JsonLoader.createObjectBuilder();
@ -73,7 +72,6 @@ public final class DayCounterInfo {
return infos;
}
// Constructors --------------------------------------------------
public DayCounterInfo(final String date, final long[] counters) {
this.date = date;

View File

@ -28,7 +28,6 @@ import org.apache.activemq.artemis.core.message.impl.CoreMessage;
* Helper class to use ActiveMQ Artemis Core messages to manage server resources.
*/
public final class ManagementHelper {
// Constants -----------------------------------------------------
public static final SimpleString HDR_RESOURCE_NAME = new SimpleString("_AMQ_ResourceName");
@ -88,9 +87,6 @@ public final class ManagementHelper {
public static final SimpleString HDR_CLIENT_ID = new SimpleString("_AMQ_Client_ID");
// Attributes ----------------------------------------------------
// Static --------------------------------------------------------
/**
* Stores a resource attribute in a message to retrieve the value from the server resource.

View File

@ -66,7 +66,6 @@ public final class MessageCounterInfo {
return new MessageCounterInfo(name, subscription, durable, count, countDelta, depth, depthDelta, lastAddTimestamp, lastAckTimestamp, updateTimestamp);
}
// Constructors --------------------------------------------------
public MessageCounterInfo(final String name,
final String subscription,

View File

@ -27,14 +27,12 @@ import org.apache.activemq.artemis.api.core.RoutingType;
*/
public final class ObjectNameBuilder {
// Constants -----------------------------------------------------
/**
* Default JMX domain for ActiveMQ Artemis resources.
*/
public static final ObjectNameBuilder DEFAULT = new ObjectNameBuilder(ActiveMQDefaultConfiguration.getDefaultJmxDomain(), "localhost", true);
// Attributes ----------------------------------------------------
private final String domain;
@ -42,7 +40,6 @@ public final class ObjectNameBuilder {
private final boolean jmxUseBrokerName;
// Static --------------------------------------------------------
public static ObjectNameBuilder create(final String domain) {
if (domain == null) {
@ -68,7 +65,7 @@ public final class ObjectNameBuilder {
}
}
// Constructors --------------------------------------------------
private ObjectNameBuilder(final String domain, final String brokerName, boolean jmxUseBrokerName) {
this.domain = domain;

View File

@ -47,8 +47,7 @@ import org.apache.activemq.artemis.utils.collections.PriorityLinkedListImpl;
import org.jboss.logging.Logger;
public final class ClientConsumerImpl implements ClientConsumerInternal {
// Constants
// ------------------------------------------------------------------------------------
private static final Logger logger = Logger.getLogger(ClientConsumerImpl.class);
@ -58,9 +57,6 @@ public final class ClientConsumerImpl implements ClientConsumerInternal {
public static final SimpleString FORCED_DELIVERY_MESSAGE = new SimpleString("_hornetq.forced.delivery.seq");
// Attributes
// -----------------------------------------------------------------------------------
private final ClientSessionInternal session;
private final SessionContext sessionContext;
@ -135,8 +131,7 @@ public final class ClientConsumerImpl implements ClientConsumerInternal {
private final ClassLoader contextClassLoader;
// Constructors
// ---------------------------------------------------------------------------------
public ClientConsumerImpl(final ClientSessionInternal session,
final ConsumerContext consumerContext,

View File

@ -64,9 +64,6 @@ public class ClientProducerImpl implements ClientProducerInternal {
private final ClientProducerCredits producerCredits;
// Static ---------------------------------------------------------------------------------------
// Constructors ---------------------------------------------------------------------------------
public ClientProducerImpl(final ClientSessionInternal session,
final SimpleString address,

View File

@ -50,11 +50,9 @@ import org.apache.activemq.artemis.utils.UTF8Util;
* saveStream are called.
*/
public class LargeMessageControllerImpl implements LargeMessageController {
// Constants -----------------------------------------------------
private static final String READ_ONLY_ERROR_MESSAGE = "This is a read-only buffer, setOperations are not supported";
// Attributes ----------------------------------------------------
private final ClientConsumerInternal consumerInternal;
@ -94,9 +92,6 @@ public class LargeMessageControllerImpl implements LargeMessageController {
private final FileCache fileCache;
private boolean local = false;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
public LargeMessageControllerImpl(final ClientConsumerInternal consumerInternal,
final long totalSize,

View File

@ -26,7 +26,7 @@ import org.apache.activemq.artemis.core.protocol.core.Packet;
import org.apache.activemq.artemis.utils.DataConstants;
public class PacketImpl implements Packet {
// Constants -------------------------------------------------------------------------
// 2.0.0
@ -287,7 +287,7 @@ public class PacketImpl implements Packet {
public static final byte DISCONNECT_V3 = -19;
// Static --------------------------------------------------------
public PacketImpl(final byte type) {
this.type = type;

View File

@ -85,8 +85,6 @@ public class RemotingConnectionImpl extends AbstractRemotingConnection implement
flush();
}
// Constructors
// ---------------------------------------------------------------------------------
/*
* Create a client side connection

View File

@ -25,9 +25,6 @@ public class ActiveMQExceptionMessage extends PacketImpl {
protected ActiveMQException exception;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
public ActiveMQExceptionMessage(final ActiveMQException exception) {
super(EXCEPTION);

View File

@ -24,9 +24,7 @@ public class ActiveMQExceptionMessage_V2 extends ActiveMQExceptionMessage {
private long correlationID;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
public ActiveMQExceptionMessage_V2(final long correlationID, final ActiveMQException exception) {
super(exception);

View File

@ -31,9 +31,6 @@ public class ClusterTopologyChangeMessage extends PacketImpl {
protected boolean last;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
public ClusterTopologyChangeMessage(final String nodeID,
final Pair<TransportConfiguration, TransportConfiguration> pair,

View File

@ -21,15 +21,10 @@ import org.apache.activemq.artemis.api.core.SimpleString;
import org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl;
public class DisconnectMessage extends PacketImpl {
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
protected SimpleString nodeID;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
public DisconnectMessage(final SimpleString nodeID) {
super(DISCONNECT);

View File

@ -20,17 +20,12 @@ import org.apache.activemq.artemis.api.core.ActiveMQBuffer;
import org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl;
public class SessionExpireMessage extends PacketImpl {
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
private long consumerID;
private long messageID;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
public SessionExpireMessage(final long consumerID, final long messageID) {
super(SESS_EXPIRED);

View File

@ -20,9 +20,7 @@ import org.apache.activemq.artemis.api.core.ActiveMQBuffer;
import org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl;
public class SessionIndividualAcknowledgeMessage extends PacketImpl {
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
private long consumerID;
@ -30,9 +28,6 @@ public class SessionIndividualAcknowledgeMessage extends PacketImpl {
private boolean requiresResponse;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
public SessionIndividualAcknowledgeMessage(final long consumerID,
final long messageID,

View File

@ -21,17 +21,12 @@ import org.apache.activemq.artemis.utils.DataConstants;
public class SessionReceiveContinuationMessage extends SessionContinuationMessage {
// Constants -----------------------------------------------------
public static final int SESSION_RECEIVE_CONTINUATION_BASE_SIZE = SESSION_CONTINUATION_BASE_SIZE + DataConstants.SIZE_LONG;
// Attributes ----------------------------------------------------
private long consumerID;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
public SessionReceiveContinuationMessage() {
super(SESS_RECEIVE_CONTINUATION);

View File

@ -23,9 +23,6 @@ import org.apache.activemq.artemis.core.message.impl.CoreMessage;
import org.apache.activemq.artemis.utils.DataConstants;
public class SessionReceiveMessage extends MessagePacket {
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
protected long consumerID;

View File

@ -45,9 +45,7 @@ public class SessionSendContinuationMessage extends SessionContinuationMessage {
*/
protected long messageBodySize = -1;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
public SessionSendContinuationMessage() {
super(SESS_SEND_CONTINUATION);

View File

@ -28,9 +28,7 @@ public class SessionSendContinuationMessage_V2 extends SessionSendContinuationMe
private long correlationID;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
public SessionSendContinuationMessage_V2() {
super();

View File

@ -28,9 +28,6 @@ public class SessionSendLargeMessage extends PacketImpl implements MessagePacket
*/
private Message largeMessage;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
public SessionSendLargeMessage(final Message largeMessage) {
super(SESS_SEND_LARGE);

View File

@ -18,13 +18,6 @@ package org.apache.activemq.artemis.core.protocol.core.impl.wireformat;
public class SessionUniqueAddMetaDataMessage extends SessionAddMetaDataMessageV2 {
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
public SessionUniqueAddMetaDataMessage() {
super(SESS_UNIQUE_ADD_METADATA);

View File

@ -26,15 +26,10 @@ import org.apache.activemq.artemis.utils.XidCodecSupport;
* to be called after a failure on an XA Session
*/
public class SessionXAAfterFailedMessage extends PacketImpl {
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
private Xid xid;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
public SessionXAAfterFailedMessage(final Xid xid) {
super(SESS_XA_FAILED);

View File

@ -23,15 +23,10 @@ import org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl;
import org.apache.activemq.artemis.utils.XidCodecSupport;
public class SessionXAStartMessage extends PacketImpl {
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
private Xid xid;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
public SessionXAStartMessage(final Xid xid) {
super(SESS_XA_START);

View File

@ -134,7 +134,6 @@ public class NettyConnector extends AbstractConnector {
private static final Logger logger = Logger.getLogger(NettyConnector.class);
// Constants -----------------------------------------------------
public static final String JAVAX_KEYSTORE_PATH_PROP_NAME = "javax.net.ssl.keyStore";
public static final String JAVAX_KEYSTORE_PASSWORD_PROP_NAME = "javax.net.ssl.keyStorePassword";
public static final String JAVAX_KEYSTORE_TYPE_PROP_NAME = "javax.net.ssl.keyStoreType";
@ -176,7 +175,6 @@ public class NettyConnector extends AbstractConnector {
DEFAULT_CONFIG = Collections.unmodifiableMap(config);
}
// Attributes ----------------------------------------------------
private final boolean serverConnection;
@ -303,10 +301,6 @@ public class NettyConnector extends AbstractConnector {
private final ClientProtocolManager protocolManager;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
// Public --------------------------------------------------------
public NettyConnector(final Map<String, Object> configuration,
final BufferHandler handler,

View File

@ -39,7 +39,6 @@ public class XidImpl implements Xid, Serializable {
private boolean hashCalculated;
// Static --------------------------------------------------------
public static String toBase64String(final Xid xid) {
byte[] data = XidImpl.toByteArray(xid);
@ -62,7 +61,7 @@ public class XidImpl implements Xid, Serializable {
return hashBytes;
}
// Constructors --------------------------------------------------
/**
* Standard constructor

View File

@ -37,7 +37,7 @@ public class VersionImpl implements Version, Serializable {
private final int[] compatibleVersionList;
// Constructors --------------------------------------------------
public VersionImpl(final String versionName,
final int majorVersion,

View File

@ -29,14 +29,9 @@ public class ActiveMQBufferInputStream extends InputStream {
/* (non-Javadoc)
* @see java.io.InputStream#read()
*/
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
private ActiveMQBuffer bb;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
// Public --------------------------------------------------------

View File

@ -24,9 +24,6 @@ import javax.naming.NamingException;
import java.util.StringTokenizer;
public class JNDIUtil {
// Constants -----------------------------------------------------
// Static --------------------------------------------------------
/**
* Create a context path recursively.
@ -89,9 +86,6 @@ public class JNDIUtil {
}
}
// Attributes ----------------------------------------------------
// Constructors --------------------------------------------------
// Public --------------------------------------------------------

View File

@ -30,7 +30,6 @@ import java.util.List;
public class ObjectInputStreamWithClassLoader extends ObjectInputStream {
// Constants ------------------------------------------------------------------------------------
/**
* Value used to indicate that all classes should be white or black listed,
@ -40,14 +39,10 @@ public class ObjectInputStreamWithClassLoader extends ObjectInputStream {
public static final String WHITELIST_PROPERTY = "org.apache.activemq.artemis.jms.deserialization.whitelist";
public static final String BLACKLIST_PROPERTY = "org.apache.activemq.artemis.jms.deserialization.blacklist";
// Attributes -----------------------------------------------------------------------------------
private List<String> whiteList = new ArrayList<>();
private List<String> blackList = new ArrayList<>();
// Static ---------------------------------------------------------------------------------------
// Constructors ---------------------------------------------------------------------------------
public ObjectInputStreamWithClassLoader(final InputStream in) throws IOException {
super(in);

View File

@ -18,7 +18,6 @@ package org.apache.activemq.artemis.utils;
public class SizeFormatterUtil {
// Constants -----------------------------------------------------
private static long oneKiB = 1024;
@ -26,10 +25,6 @@ public class SizeFormatterUtil {
private static long oneGiB = SizeFormatterUtil.oneMiB * 1024;
// Attributes ----------------------------------------------------
// Static --------------------------------------------------------
public static String sizeof(final long size) {
double s = Long.valueOf(size).doubleValue();
String suffix = "B";
@ -45,7 +40,6 @@ public class SizeFormatterUtil {
}
return String.format("%.2f %s", s, suffix);
}
// Constructors --------------------------------------------------
// Public --------------------------------------------------------

View File

@ -44,18 +44,14 @@ public class SoftValueLongObjectHashMap<V extends SoftValueLongObjectHashMap.Val
private int maxElements;
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
// Static --------------------------------------------------------
public interface ValueCache {
boolean isLive();
}
// Constructors --------------------------------------------------
public SoftValueLongObjectHashMap(final int maxElements) {
this.maxElements = maxElements;

View File

@ -25,7 +25,7 @@ import java.util.concurrent.atomic.AtomicLong;
* </p>
*/
public class TimeAndCounterIDGenerator implements IDGenerator {
// Constants ----------------------------------------------------
/**
* Bits to move the date accordingly to MASK_TIME
@ -40,7 +40,6 @@ public class TimeAndCounterIDGenerator implements IDGenerator {
private static final long TIME_ID_MASK = 0x7fffffffff000000L;
// Attributes ----------------------------------------------------
private final AtomicLong counter = new AtomicLong(0);
@ -48,9 +47,6 @@ public class TimeAndCounterIDGenerator implements IDGenerator {
private volatile long tmMark;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
public TimeAndCounterIDGenerator() {
refresh();

View File

@ -23,11 +23,6 @@ import org.apache.activemq.artemis.core.transaction.impl.XidImpl;
public class XidCodecSupport {
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
// Static --------------------------------------------------------
public static void encodeXid(final Xid xid, final ActiveMQBuffer out) {
out.writeInt(xid.getFormatId());
@ -50,7 +45,6 @@ public class XidCodecSupport {
return DataConstants.SIZE_INT * 3 + xid.getBranchQualifier().length + xid.getGlobalTransactionId().length;
}
// Constructors --------------------------------------------------
// Public --------------------------------------------------------

View File

@ -26,14 +26,6 @@ import org.junit.Test;
public class TimeAndCounterIDGeneratorTest extends Assert {
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
// Public --------------------------------------------------------
@Test

View File

@ -25,7 +25,7 @@ import org.w3c.dom.Node;
import org.w3c.dom.NodeList;
public class XMLUtilTest extends SilentTestCase {
// Constructors --------------------------------------------------
// Public --------------------------------------------------------

View File

@ -58,14 +58,11 @@ import static org.apache.activemq.artemis.reader.BytesMessageUtil.bytesWriteUTF;
*/
public class ActiveMQBytesMessage extends ActiveMQMessage implements BytesMessage {
// Static -------------------------------------------------------
public static final byte TYPE = Message.BYTES_TYPE;
// Attributes ----------------------------------------------------
private int bodyLength;
// Constructor ---------------------------------------------------
/**
* This constructor is used to construct messages prior to sending

View File

@ -66,7 +66,7 @@ import org.apache.activemq.artemis.utils.collections.ConcurrentHashSet;
*/
public class ActiveMQConnection extends ActiveMQConnectionForContextImpl implements TopicConnection, QueueConnection {
// Constants ------------------------------------------------------------------------------------
public static final int TYPE_GENERIC_CONNECTION = 0;
public static final int TYPE_QUEUE_CONNECTION = 1;
@ -79,9 +79,6 @@ public class ActiveMQConnection extends ActiveMQConnectionForContextImpl impleme
public static final SimpleString CONNECTION_ID_PROPERTY_NAME = MessageUtil.CONNECTION_ID_PROPERTY_NAME;
// Static ---------------------------------------------------------------------------------------
// Attributes -----------------------------------------------------------------------------------
private final int connectionType;
@ -137,7 +134,6 @@ public class ActiveMQConnection extends ActiveMQConnectionForContextImpl impleme
private final ConnectionFactoryOptions options;
// Constructors ---------------------------------------------------------------------------------
public ActiveMQConnection(final ConnectionFactoryOptions options,
final String username,

View File

@ -49,17 +49,13 @@ public class ActiveMQConnectionMetaData implements ConnectionMetaData {
JMS_MINOR_VERSION = Integer.valueOf(versionProps.getProperty("activemq.version.implementation.minorVersion", "0"));
}
// Constants -----------------------------------------------------
private static final String ACTIVEMQ = "ActiveMQ";
// Static --------------------------------------------------------
// Attributes ----------------------------------------------------
private final Version serverVersion;
// Constructors --------------------------------------------------
/**
* Create a new ActiveMQConnectionMetaData object.

View File

@ -37,9 +37,7 @@ import org.apache.activemq.artemis.utils.DestinationUtil;
* ActiveMQ Artemis implementation of a JMS Destination.
*/
public class ActiveMQDestination extends JNDIStorable implements Destination, Serializable {
// Constants -----------------------------------------------------
// Static --------------------------------------------------------
private static final long serialVersionUID = 5027962425462382883L;
@ -292,7 +290,6 @@ public class ActiveMQDestination extends JNDIStorable implements Destination, Se
return createTemporaryTopic(address, null);
}
// Attributes ----------------------------------------------------
/**
* The core address
@ -318,7 +315,7 @@ public class ActiveMQDestination extends JNDIStorable implements Destination, Se
private final transient ActiveMQSession session;
private transient boolean created;
// Constructors --------------------------------------------------
protected ActiveMQDestination(final String address,
final TYPE type,

View File

@ -37,19 +37,14 @@ import static org.apache.activemq.artemis.reader.MapMessageUtil.writeBodyMap;
* ActiveMQ Artemis implementation of a JMS MapMessage.
*/
public class ActiveMQMapMessage extends ActiveMQMessage implements MapMessage {
// Constants -----------------------------------------------------
public static final byte TYPE = Message.MAP_TYPE;
// Attributes ----------------------------------------------------
private final TypedProperties map = new TypedProperties();
private boolean invalid;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
/*
* This constructor is used to construct messages prior to sending

View File

@ -63,7 +63,6 @@ import static org.apache.activemq.artemis.jms.client.ActiveMQDestination.TOPIC_Q
*/
public class ActiveMQMessage implements javax.jms.Message {
// Constants -----------------------------------------------------
public static final byte TYPE = org.apache.activemq.artemis.api.core.Message.DEFAULT_TYPE;
public static final SimpleString OLD_QUEUE_QUALIFIED_PREFIX = SimpleString.toSimpleString(ActiveMQDestination.QUEUE_QUALIFIED_PREFIX + PacketImpl.OLD_QUEUE_PREFIX);
@ -110,7 +109,6 @@ public class ActiveMQMessage implements javax.jms.Message {
return jmsdata;
}
// Static --------------------------------------------------------
private static final HashSet<String> reservedIdentifiers = new HashSet<>();
@ -172,7 +170,6 @@ public class ActiveMQMessage implements javax.jms.Message {
return msg;
}
// Attributes ----------------------------------------------------
// The underlying message
protected ClientMessage message;
@ -206,7 +203,6 @@ public class ActiveMQMessage implements javax.jms.Message {
private long jmsDeliveryTime;
// Constructors --------------------------------------------------
/*
* Create a new message prior to sending

View File

@ -66,7 +66,7 @@ public final class ActiveMQMessageConsumer implements QueueReceiver, TopicSubscr
private final SimpleString autoDeleteQueueName;
// Constructors --------------------------------------------------
protected ActiveMQMessageConsumer(final ConnectionFactoryOptions options,
final ActiveMQConnection connection,

View File

@ -72,7 +72,6 @@ public class ActiveMQMessageProducer implements MessageProducer, QueueSender, To
private long defaultDeliveryDelay = Message.DEFAULT_DELIVERY_DELAY;
private final ActiveMQDestination defaultDestination;
// Constructors --------------------------------------------------
protected ActiveMQMessageProducer(final ActiveMQConnection connection,
final ClientProducer producer,

View File

@ -38,20 +38,16 @@ import org.apache.activemq.artemis.utils.ObjectInputStreamWithClassLoader;
* Serialization is slooooow!
*/
public class ActiveMQObjectMessage extends ActiveMQMessage implements ObjectMessage {
// Constants -----------------------------------------------------
public static final byte TYPE = Message.OBJECT_TYPE;
// Attributes ----------------------------------------------------
// keep a snapshot of the Serializable Object as a byte[] to provide Object isolation
private byte[] data;
private final ConnectionFactoryOptions options;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
protected ActiveMQObjectMessage(final ClientSession session, ConnectionFactoryOptions options) {
super(ActiveMQObjectMessage.TYPE, session);

View File

@ -27,14 +27,9 @@ import org.apache.activemq.artemis.api.core.SimpleString;
*/
public class ActiveMQQueue extends ActiveMQDestination implements Queue {
// Constants -----------------------------------------------------
private static final long serialVersionUID = -1106092883162295462L;
// Static --------------------------------------------------------
// Attributes ----------------------------------------------------
// Constructors --------------------------------------------------
public ActiveMQQueue() {
this((SimpleString) null);
}

View File

@ -34,11 +34,7 @@ import org.apache.activemq.artemis.utils.SelectorTranslator;
* ActiveMQ Artemis implementation of a JMS QueueBrowser.
*/
public final class ActiveMQQueueBrowser implements QueueBrowser {
// Constants ------------------------------------------------------------------------------------
// Static ---------------------------------------------------------------------------------------
// Attributes -----------------------------------------------------------------------------------
private final ConnectionFactoryOptions options;
@ -52,7 +48,7 @@ public final class ActiveMQQueueBrowser implements QueueBrowser {
private final boolean enable1xPrefixes;
// Constructors ---------------------------------------------------------------------------------
protected ActiveMQQueueBrowser(final ConnectionFactoryOptions options,
final ActiveMQQueue queue,

View File

@ -120,7 +120,6 @@ public class ActiveMQSession implements QueueSession, TopicSession {
private final Map<String, Queue> queueCache = new ConcurrentHashMap<>();
// Constructors --------------------------------------------------
protected ActiveMQSession(final ConnectionFactoryOptions options,
final ActiveMQConnection connection,

View File

@ -24,15 +24,10 @@ import javax.jms.TemporaryQueue;
* This class can be instantiated directly.
*/
public class ActiveMQTemporaryQueue extends ActiveMQQueue implements TemporaryQueue {
// Constants -----------------------------------------------------
private static final long serialVersionUID = -4624930377557954624L;
// Static --------------------------------------------------------
// Attributes ----------------------------------------------------
// Constructors --------------------------------------------------
// TemporaryQueue implementation ------------------------------------------

View File

@ -20,15 +20,10 @@ import javax.jms.TemporaryTopic;
public class ActiveMQTemporaryTopic extends ActiveMQTopic implements TemporaryTopic {
// Constants -----------------------------------------------------
private static final long serialVersionUID = 845450764835635266L;
// Attributes ----------------------------------------------------
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
public ActiveMQTemporaryTopic() {
this(null, null);
}

View File

@ -34,19 +34,14 @@ import static org.apache.activemq.artemis.reader.TextMessageUtil.writeBodyText;
* This class was ported from SpyTextMessage in JBossMQ.
*/
public class ActiveMQTextMessage extends ActiveMQMessage implements TextMessage {
// Constants -----------------------------------------------------
public static final byte TYPE = Message.TEXT_TYPE;
// Attributes ----------------------------------------------------
// We cache it locally - it's more performant to cache as a SimpleString, the AbstractChannelBuffer write
// methods are more efficient for a SimpleString
private SimpleString text;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
public ActiveMQTextMessage(final ClientSession session) {
super(ActiveMQTextMessage.TYPE, session);

View File

@ -26,14 +26,10 @@ import org.apache.activemq.artemis.api.core.SimpleString;
* This class can be instantiated directly.
*/
public class ActiveMQTopic extends ActiveMQDestination implements Topic {
// Constants -----------------------------------------------------
private static final long serialVersionUID = 7873614001276404156L;
// Static --------------------------------------------------------
// Attributes ----------------------------------------------------
// Constructors --------------------------------------------------
public ActiveMQTopic() {
this((SimpleString) null);
}

View File

@ -26,7 +26,6 @@ public class JMSBridgeControlImpl extends StandardMBean implements JMSBridgeCont
private final JMSBridge bridge;
// Constructors --------------------------------------------------
public JMSBridgeControlImpl(final JMSBridge bridge) throws Exception {
super(JMSBridgeControl.class);
@ -207,11 +206,6 @@ public class JMSBridgeControlImpl extends StandardMBean implements JMSBridgeCont
bridge.setTargetUsername(name);
}
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
// Static --------------------------------------------------------
// Package protected ---------------------------------------------

View File

@ -26,9 +26,6 @@ import org.apache.activemq.artemis.utils.DataConstants;
public class PersistedBindings implements EncodingSupport {
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
private long id;
@ -38,9 +35,6 @@ public class PersistedBindings implements EncodingSupport {
private ArrayList<String> bindings = new ArrayList<>();
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
public PersistedBindings() {
}

View File

@ -23,9 +23,6 @@ import org.apache.activemq.artemis.jms.server.config.impl.ConnectionFactoryConfi
public class PersistedConnectionFactory implements EncodingSupport {
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
private long id;
@ -43,9 +40,6 @@ public class PersistedConnectionFactory implements EncodingSupport {
this.config = config;
}
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
// Public --------------------------------------------------------

View File

@ -24,9 +24,6 @@ import org.apache.activemq.artemis.utils.DataConstants;
public class PersistedDestination implements EncodingSupport {
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
private long id;
@ -37,9 +34,6 @@ public class PersistedDestination implements EncodingSupport {
private String selector;
private boolean durable;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
public PersistedDestination() {
}

View File

@ -46,7 +46,7 @@ import org.apache.activemq.artemis.utils.IDGenerator;
public final class JMSJournalStorageManagerImpl implements JMSStorageManager {
// Constants -----------------------------------------------------
public static final byte CF_RECORD = 1;
@ -54,7 +54,6 @@ public final class JMSJournalStorageManagerImpl implements JMSStorageManager {
public static final byte BINDING_RECORD = 3;
// Attributes ----------------------------------------------------
private final IDGenerator idGenerator;
@ -72,9 +71,7 @@ public final class JMSJournalStorageManagerImpl implements JMSStorageManager {
private final Configuration config;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
public JMSJournalStorageManagerImpl(ExecutorFactory ioExecutors,
final IDGenerator idGenerator,
final Configuration config,

View File

@ -37,9 +37,7 @@ import org.apache.activemq.artemis.utils.DataConstants;
* Every property on this class has to be also set through encoders through EncodingSupport implementation at this class.
*/
public class ConnectionFactoryConfigurationImpl implements ConnectionFactoryConfiguration {
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
private String name = null;
@ -130,10 +128,6 @@ public class ConnectionFactoryConfigurationImpl implements ConnectionFactoryConf
private boolean useTopologyForLoadBalancing = ActiveMQClient.DEFAULT_USE_TOPOLOGY_FOR_LOADBALANCING;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
public ConnectionFactoryConfigurationImpl() {
}

View File

@ -20,9 +20,6 @@ import org.apache.activemq.artemis.jms.server.config.JMSQueueConfiguration;
public class JMSQueueConfigurationImpl implements JMSQueueConfiguration {
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
private String name = null;
@ -32,9 +29,6 @@ public class JMSQueueConfigurationImpl implements JMSQueueConfiguration {
private String[] bindings = null;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
public JMSQueueConfigurationImpl() {
}

View File

@ -20,17 +20,10 @@ import org.apache.activemq.artemis.jms.server.config.TopicConfiguration;
public class TopicConfigurationImpl implements TopicConfiguration {
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
private String name;
private String[] bindings;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
public TopicConfigurationImpl() {
}

View File

@ -111,13 +111,6 @@ public class TransportConfigurationEncodingSupport {
return size;
}
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
// Public --------------------------------------------------------

View File

@ -51,12 +51,12 @@ public final class TimedBuffer extends CriticalComponentImpl {
private static final double MAX_TIMEOUT_ERROR_FACTOR = 1.5;
// Constants -----------------------------------------------------
// The number of tries on sleep before switching to spin
private static final int MAX_CHECKS_ON_SLEEP = 20;
// Attributes ----------------------------------------------------
// If the TimedBuffer is idle - i.e. no records are being added, then it's pointless the timer flush thread
// in spinning and checking the time - and using up CPU in the process - this semaphore is used to
// prevent that
@ -88,9 +88,6 @@ public final class TimedBuffer extends CriticalComponentImpl {
// no need to be volatile as every access is synchronized
private boolean spinning = false;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
// Public --------------------------------------------------------

View File

@ -38,9 +38,6 @@ import org.apache.activemq.artemis.utils.collections.ConcurrentLongHashSet;
*/
public abstract class AbstractJournalUpdateTask implements JournalReaderCallback {
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
public static final String FILE_COMPACT_CONTROL = "journal-rename-control.ctr";
protected final JournalImpl journal;
@ -63,9 +60,6 @@ public abstract class AbstractJournalUpdateTask implements JournalReaderCallback
protected final List<JournalFile> newDataFiles = new ArrayList<>();
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
protected AbstractJournalUpdateTask(final SequentialFileFactory fileFactory,
final JournalImpl journal,

View File

@ -202,7 +202,7 @@ public class JournalImpl extends JournalBase implements TestableJournal, Journal
protected static final byte FILL_CHARACTER = (byte) 'J';
// Attributes ----------------------------------------------------
private volatile boolean autoReclaim = true;
@ -355,7 +355,7 @@ public class JournalImpl extends JournalBase implements TestableJournal, Journal
public JournalFilesRepository getFilesRepository() {
return filesRepository;
}
// Constructors --------------------------------------------------
public JournalImpl(final int fileSize,
final int minFiles,

View File

@ -23,13 +23,6 @@ import org.apache.activemq.artemis.core.journal.IOCompletion;
*/
public abstract class SyncIOCompletion implements IOCompletion {
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
// Public --------------------------------------------------------

View File

@ -43,15 +43,12 @@ public class CoreTextMessageWrapper extends CoreMessageWrapper {
public static final byte TYPE = Message.TEXT_TYPE;
// Attributes ----------------------------------------------------
// We cache it locally - it's more performant to cache as a SimpleString, the AbstractChannelBuffer write
// methods are more efficient for a SimpleString
private SimpleString text;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
/*
* This constructor is used to construct messages prior to sending

View File

@ -71,9 +71,7 @@ public class StompProtocolManager extends AbstractProtocolManager<StompFrame, St
private final List<StompFrameInterceptor> incomingInterceptors;
private final List<StompFrameInterceptor> outgoingInterceptors;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
StompProtocolManager(final StompProtocolManagerFactory factory,
final ActiveMQServer server,

View File

@ -31,12 +31,8 @@ import org.apache.activemq.artemis.reader.MessageUtil;
public class StompUtils {
// Constants -----------------------------------------------------
private static final String DEFAULT_MESSAGE_PRIORITY = "4";
// Attributes ----------------------------------------------------
// Static --------------------------------------------------------
public static void copyStandardHeadersFromFrameToMessage(StompFrame frame, Message msg, String prefix) throws Exception {
Map<String, String> headers = new HashMap<>(frame.getHeadersMap());
@ -153,7 +149,6 @@ public class StompUtils {
command.addHeader(name.toString(), message.getObjectProperty(name).toString());
}
}
// Constructors --------------------------------------------------
// Public --------------------------------------------------------

View File

@ -26,16 +26,12 @@ import java.util.Set;
* https://jira.jboss.org/browse/HORNETQ-339
*/
public class ActiveMQRAService {
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
private final MBeanServer mBeanServer;
private final String resourceAdapterObjectName;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
public ActiveMQRAService(final MBeanServer mBeanServer, final String resourceAdapterObjectName) {
this.mBeanServer = mBeanServer;

View File

@ -93,7 +93,6 @@ import org.apache.activemq.artemis.utils.uri.BeanSupport;
import org.jboss.logging.Logger;
public class ConfigurationImpl implements Configuration, Serializable {
// Constants ------------------------------------------------------------------------------
private static final Logger logger = Logger.getLogger(ConfigurationImpl.class);
@ -107,8 +106,6 @@ public class ConfigurationImpl implements Configuration, Serializable {
private static final long serialVersionUID = 4077088945050267843L;
// Attributes -----------------------------------------------------------------------------
private String name = "localhost";
private boolean persistenceEnabled = ActiveMQDefaultConfiguration.isDefaultPersistenceEnabled();

View File

@ -321,7 +321,6 @@ public final class FileConfigurationParser extends XMLConfigurationUtil {
private static final String ENABLE_INGRESS_TIMESTAMP = "enable-ingress-timestamp";
// Attributes ----------------------------------------------------
private boolean validateAIO = false;

View File

@ -54,13 +54,11 @@ import static org.apache.activemq.artemis.api.core.FilterConstants.NATIVE_MESSAG
*/
public class FilterImpl implements Filter {
// Constants -----------------------------------------------------
private final SimpleString sfilterString;
private final BooleanExpression booleanExpression;
// Static ---------------------------------------------------------
/**
* @return null if <code>filterStr</code> is null or an empty String and a valid filter else
@ -92,8 +90,6 @@ public class FilterImpl implements Filter {
return new FilterImpl(filterStr, booleanExpression);
}
// Constructors ---------------------------------------------------
private FilterImpl(final SimpleString str, final BooleanExpression expression) {
sfilterString = str;
this.booleanExpression = expression;

View File

@ -41,15 +41,9 @@ import org.apache.activemq.artemis.utils.UUIDGenerator;
public abstract class AbstractControl extends StandardMBean {
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
protected final StorageManager storageManager;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
public AbstractControl(final Class<?> clazz, final StorageManager storageManager) throws NotCompliantMBeanException {
super(clazz);

View File

@ -29,17 +29,11 @@ import org.apache.activemq.artemis.spi.core.remoting.Acceptor;
public class AcceptorControlImpl extends AbstractControl implements AcceptorControl {
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
private final Acceptor acceptor;
private final TransportConfiguration configuration;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
public AcceptorControlImpl(final Acceptor acceptor,
final StorageManager storageManager,

View File

@ -139,10 +139,9 @@ import org.apache.activemq.artemis.utils.collections.TypedProperties;
import org.jboss.logging.Logger;
public class ActiveMQServerControlImpl extends AbstractControl implements ActiveMQServerControl, NotificationEmitter, org.apache.activemq.artemis.core.server.management.NotificationListener {
// Constants -----------------------------------------------------
private static final Logger logger = Logger.getLogger(ActiveMQServerControlImpl.class);
// Attributes ----------------------------------------------------
private final PostOffice postOffice;

View File

@ -57,9 +57,6 @@ import org.apache.activemq.artemis.utils.JsonLoader;
public class AddressControlImpl extends AbstractControl implements AddressControl {
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
private AddressInfo addressInfo;
@ -73,9 +70,6 @@ public class AddressControlImpl extends AbstractControl implements AddressContro
private final ManagementService managementService;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
public AddressControlImpl(AddressInfo addressInfo,
final ActiveMQServer server,

View File

@ -28,19 +28,12 @@ import javax.management.MBeanOperationInfo;
public class BaseBroadcastGroupControlImpl extends AbstractControl implements BaseBroadcastGroupControl {
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
private Class broadcastGroupControlClass;
private final BroadcastGroup broadcastGroup;
private final BroadcastGroupConfiguration configuration;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
public BaseBroadcastGroupControlImpl(final BroadcastGroup broadcastGroup,
final StorageManager storageManager,

View File

@ -31,17 +31,11 @@ import org.apache.activemq.artemis.logs.AuditLogger;
public class BridgeControlImpl extends AbstractControl implements BridgeControl {
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
private final Bridge bridge;
private final BridgeConfiguration configuration;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
public BridgeControlImpl(final Bridge bridge,
final StorageManager storageManager,

View File

@ -25,15 +25,10 @@ import org.apache.activemq.artemis.logs.AuditLogger;
public class BroadcastGroupControlImpl extends BaseBroadcastGroupControlImpl implements BroadcastGroupControl {
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
private UDPBroadcastEndpointFactory endpointFactory;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
public BroadcastGroupControlImpl(final BroadcastGroup broadcastGroup,
final StorageManager storageManager,

View File

@ -32,17 +32,13 @@ import org.apache.activemq.artemis.logs.AuditLogger;
public class ClusterConnectionControlImpl extends AbstractControl implements ClusterConnectionControl {
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
private final ClusterConnection clusterConnection;
private final ClusterConnectionConfiguration configuration;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
public ClusterConnectionControlImpl(final ClusterConnection clusterConnection,
final StorageManager storageManager,

View File

@ -34,17 +34,11 @@ import org.apache.activemq.artemis.logs.AuditLogger;
public class DivertControlImpl extends AbstractControl implements DivertControl {
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
private final Divert divert;
private final String internalNamingPrefix;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
// DivertControlMBean implementation ---------------------------

View File

@ -25,16 +25,9 @@ import org.apache.activemq.artemis.logs.AuditLogger;
public class JGroupsChannelBroadcastGroupControlImpl extends BaseBroadcastGroupControlImpl implements JGroupsChannelBroadcastGroupControl {
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
private ChannelBroadcastEndpointFactory endpointFactory;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
public JGroupsChannelBroadcastGroupControlImpl(final BroadcastGroup broadcastGroup,
final StorageManager storageManager,
final BroadcastGroupConfiguration configuration,

View File

@ -30,15 +30,10 @@ import java.nio.file.Paths;
public class JGroupsFileBroadcastGroupControlImpl extends BaseBroadcastGroupControlImpl implements JGroupsFileBroadcastGroupControl {
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
private JGroupsFileBroadcastEndpointFactory endpointFactory;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
public JGroupsFileBroadcastGroupControlImpl(final BroadcastGroup broadcastGroup,
final StorageManager storageManager,

View File

@ -25,15 +25,9 @@ import org.apache.activemq.artemis.logs.AuditLogger;
public class JGroupsPropertiesBroadcastGroupControlImpl extends BaseBroadcastGroupControlImpl implements JGroupsPropertiesBroadcastGroupControl {
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
private JGroupsPropertiesBroadcastEndpointFactory endpointFactory;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
public JGroupsPropertiesBroadcastGroupControlImpl(final BroadcastGroup broadcastGroup,
final StorageManager storageManager,

View File

@ -29,13 +29,7 @@ import org.apache.activemq.artemis.api.core.management.Operation;
import org.apache.activemq.artemis.api.core.management.Parameter;
public class MBeanInfoHelper {
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
// Public --------------------------------------------------------

View File

@ -68,9 +68,6 @@ public class QueueControlImpl extends AbstractControl implements QueueControl {
public static final int FLUSH_LIMIT = 500;
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
private final Queue queue;
@ -84,7 +81,6 @@ public class QueueControlImpl extends AbstractControl implements QueueControl {
private MessageCounter counter;
// Static --------------------------------------------------------
private static String toJSON(final Map<String, Object>[] messages) {
JsonArray array = toJSONMsgArray(messages);
@ -111,8 +107,6 @@ public class QueueControlImpl extends AbstractControl implements QueueControl {
return arrayReturn.build().toString();
}
// Constructors --------------------------------------------------
public QueueControlImpl(final Queue queue,
final String address,
final ActiveMQServer server,

View File

@ -38,9 +38,7 @@ import static org.apache.activemq.artemis.api.core.JsonUtil.nullSafe;
* regular intervals - this means we are less intrusive on the queue
*/
public class MessageCounter {
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
// destination related information
private final String destName;
@ -75,9 +73,6 @@ public class MessageCounter {
private long lastMessagesAcked;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
/**
* Constructor

View File

@ -27,11 +27,7 @@ import org.apache.activemq.artemis.core.messagecounter.MessageCounter;
import org.apache.activemq.artemis.core.messagecounter.MessageCounter.DayCounter;
public class MessageCounterHelper {
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
// Static --------------------------------------------------------
public static String listMessageCounterHistory(final MessageCounter counter) throws Exception {
List<DayCounter> history = counter.getHistory();
@ -177,8 +173,6 @@ public class MessageCounterHelper {
}
}
// Constructors --------------------------------------------------
// Public --------------------------------------------------------
// Package protected ---------------------------------------------

View File

@ -56,11 +56,10 @@ import org.jboss.logging.Logger;
* However I want to keep this isolated as much as possible during development
*/
public class PageCursorProviderImpl implements PageCursorProvider {
// Constants -----------------------------------------------------
private static final Logger logger = Logger.getLogger(PageCursorProviderImpl.class);
// Attributes ----------------------------------------------------
/**
* As an optimization, avoid subsequent schedules as they are unnecessary
@ -93,9 +92,7 @@ public class PageCursorProviderImpl implements PageCursorProvider {
//storageManager.beforePageRead will be attempted in a loop, printing at intervals a warn message
private static final long PAGE_READ_PERMISSION_TIMEOUT_NS = TimeUnit.SECONDS.toNanos(10);
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
public PageCursorProviderImpl(final PagingStore pagingStore,
final StorageManager storageManager,
final ArtemisExecutor executor,

View File

@ -43,7 +43,6 @@ import org.jboss.logging.Logger;
public final class Page implements Comparable<Page> {
// Constants -----------------------------------------------------
private static final Logger logger = Logger.getLogger(Page.class);
public static final int SIZE_RECORD = DataConstants.SIZE_BYTE + DataConstants.SIZE_INT + DataConstants.SIZE_BYTE;
@ -52,7 +51,6 @@ public final class Page implements Comparable<Page> {
private static final byte END_BYTE = (byte) '}';
// Attributes ----------------------------------------------------
private final int pageId;

View File

@ -32,9 +32,7 @@ import org.apache.activemq.artemis.core.server.ActiveMQScheduledComponent;
*/
final class PageSyncTimer extends ActiveMQScheduledComponent {
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
private final PagingStore store;
@ -53,9 +51,6 @@ final class PageSyncTimer extends ActiveMQScheduledComponent {
private final List<OperationContext> syncOperations = new LinkedList<>();
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
PageSyncTimer(PagingStore store, ScheduledExecutorService scheduledExecutor, Executor executor, long timeSync) {
super(scheduledExecutor, executor, timeSync, TimeUnit.NANOSECONDS, true);

View File

@ -38,9 +38,7 @@ import org.apache.activemq.artemis.utils.DataConstants;
import org.jboss.logging.Logger;
public final class PageTransactionInfoImpl implements PageTransactionInfo {
// Constants -----------------------------------------------------
// Attributes ----------------------------------------------------
private static final Logger logger = Logger.getLogger(PageTransactionInfoImpl.class);
@ -65,10 +63,6 @@ public final class PageTransactionInfoImpl implements PageTransactionInfo {
private List<LateDelivery> lateDeliveries;
// Static --------------------------------------------------------
// Constructors --------------------------------------------------
public PageTransactionInfoImpl(final long transactionID) {
this();
this.transactionID = transactionID;

View File

@ -91,11 +91,7 @@ public final class PagingManagerImpl implements PagingManager {
private final SimpleString managementAddress;
// Static
// --------------------------------------------------------------------------------------------------------------------------
// Constructors
// --------------------------------------------------------------------------------------------------------------------
// for tests.. not part of the API

View File

@ -52,13 +52,12 @@ import org.apache.activemq.artemis.utils.actors.ArtemisExecutor;
*/
public class PagingStoreFactoryDatabase implements PagingStoreFactory {
// Constants -----------------------------------------------------
private static final String ADDRESS_FILE = "address.txt";
private static final String DIRECTORY_NAME = "directory.txt";
// Attributes ----------------------------------------------------
protected final boolean syncNonTransactional;

View File

@ -54,11 +54,9 @@ import org.apache.activemq.artemis.utils.actors.ArtemisExecutor;
*/
public class PagingStoreFactoryNIO implements PagingStoreFactory {
// Constants -----------------------------------------------------
public static final String ADDRESS_FILE = "address.txt";
// Attributes ----------------------------------------------------
private final File directory;

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