Fix checkstyle redundant modifier violations

This commit is contained in:
Ville Skyttä 2016-06-13 18:49:01 +03:00
parent d0d023b262
commit 3923ae45f4
142 changed files with 310 additions and 310 deletions

View File

@ -289,7 +289,7 @@ public class PrintData extends LockAbstract {
private final Map<Long, Set<Long>> completePages = new HashMap<>(); private final Map<Long, Set<Long>> completePages = new HashMap<>();
public PageCursorsInfo() { private PageCursorsInfo() {
} }
/** /**

View File

@ -935,7 +935,7 @@ public final class XmlDataExporter extends LockAbstract {
boolean wrap = true; boolean wrap = true;
public PrettyPrintHandler(XMLStreamWriter target) { PrettyPrintHandler(XMLStreamWriter target) {
this.target = target; this.target = target;
} }

View File

@ -43,7 +43,7 @@ public class ReusableLatch {
@SuppressWarnings("serial") @SuppressWarnings("serial")
private static class CountSync extends AbstractQueuedSynchronizer { private static class CountSync extends AbstractQueuedSynchronizer {
public CountSync(int count) { private CountSync(int count) {
setState(count); setState(count);
} }

View File

@ -598,7 +598,7 @@ public final class TypedProperties {
private static final class NullValue extends PropertyValue { private static final class NullValue extends PropertyValue {
public NullValue() { private NullValue() {
} }
@Override @Override
@ -622,11 +622,11 @@ public final class TypedProperties {
final boolean val; final boolean val;
public BooleanValue(final boolean val) { private BooleanValue(final boolean val) {
this.val = val; this.val = val;
} }
public BooleanValue(final ActiveMQBuffer buffer) { private BooleanValue(final ActiveMQBuffer buffer) {
val = buffer.readBoolean(); val = buffer.readBoolean();
} }
@ -652,11 +652,11 @@ public final class TypedProperties {
final byte val; final byte val;
public ByteValue(final byte val) { private ByteValue(final byte val) {
this.val = val; this.val = val;
} }
public ByteValue(final ActiveMQBuffer buffer) { private ByteValue(final ActiveMQBuffer buffer) {
val = buffer.readByte(); val = buffer.readByte();
} }
@ -681,11 +681,11 @@ public final class TypedProperties {
final byte[] val; final byte[] val;
public BytesValue(final byte[] val) { private BytesValue(final byte[] val) {
this.val = val; this.val = val;
} }
public BytesValue(final ActiveMQBuffer buffer) { private BytesValue(final ActiveMQBuffer buffer) {
int len = buffer.readInt(); int len = buffer.readInt();
val = new byte[len]; val = new byte[len];
buffer.readBytes(val); buffer.readBytes(val);
@ -714,11 +714,11 @@ public final class TypedProperties {
final short val; final short val;
public ShortValue(final short val) { private ShortValue(final short val) {
this.val = val; this.val = val;
} }
public ShortValue(final ActiveMQBuffer buffer) { private ShortValue(final ActiveMQBuffer buffer) {
val = buffer.readShort(); val = buffer.readShort();
} }
@ -743,11 +743,11 @@ public final class TypedProperties {
final int val; final int val;
public IntValue(final int val) { private IntValue(final int val) {
this.val = val; this.val = val;
} }
public IntValue(final ActiveMQBuffer buffer) { private IntValue(final ActiveMQBuffer buffer) {
val = buffer.readInt(); val = buffer.readInt();
} }
@ -772,11 +772,11 @@ public final class TypedProperties {
final long val; final long val;
public LongValue(final long val) { private LongValue(final long val) {
this.val = val; this.val = val;
} }
public LongValue(final ActiveMQBuffer buffer) { private LongValue(final ActiveMQBuffer buffer) {
val = buffer.readLong(); val = buffer.readLong();
} }
@ -801,11 +801,11 @@ public final class TypedProperties {
final float val; final float val;
public FloatValue(final float val) { private FloatValue(final float val) {
this.val = val; this.val = val;
} }
public FloatValue(final ActiveMQBuffer buffer) { private FloatValue(final ActiveMQBuffer buffer) {
val = Float.intBitsToFloat(buffer.readInt()); val = Float.intBitsToFloat(buffer.readInt());
} }
@ -831,11 +831,11 @@ public final class TypedProperties {
final double val; final double val;
public DoubleValue(final double val) { private DoubleValue(final double val) {
this.val = val; this.val = val;
} }
public DoubleValue(final ActiveMQBuffer buffer) { private DoubleValue(final ActiveMQBuffer buffer) {
val = Double.longBitsToDouble(buffer.readLong()); val = Double.longBitsToDouble(buffer.readLong());
} }
@ -860,11 +860,11 @@ public final class TypedProperties {
final char val; final char val;
public CharValue(final char val) { private CharValue(final char val) {
this.val = val; this.val = val;
} }
public CharValue(final ActiveMQBuffer buffer) { private CharValue(final ActiveMQBuffer buffer) {
val = (char) buffer.readShort(); val = (char) buffer.readShort();
} }
@ -889,11 +889,11 @@ public final class TypedProperties {
final SimpleString val; final SimpleString val;
public StringValue(final SimpleString val) { private StringValue(final SimpleString val) {
this.val = val; this.val = val;
} }
public StringValue(final ActiveMQBuffer buffer) { private StringValue(final ActiveMQBuffer buffer) {
val = buffer.readSimpleString(); val = buffer.readSimpleString();
} }

View File

@ -113,7 +113,7 @@ public final class UDPBroadcastEndpointFactory implements BroadcastEndpointFacto
private volatile boolean open; private volatile boolean open;
public UDPBroadcastEndpoint() { private UDPBroadcastEndpoint() {
} }
public UDPBroadcastEndpoint setGroupAddress(InetAddress groupAddress) { public UDPBroadcastEndpoint setGroupAddress(InetAddress groupAddress) {

View File

@ -43,7 +43,7 @@ public enum CoreNotificationType implements NotificationType {
private final int value; private final int value;
private CoreNotificationType(final int value) { CoreNotificationType(final int value) {
this.value = value; this.value = value;
} }

View File

@ -318,7 +318,7 @@ public class ClientMessageImpl extends MessageImpl implements ClientMessageInter
private final class DecodingContext implements BodyEncoder { private final class DecodingContext implements BodyEncoder {
public DecodingContext() { private DecodingContext() {
} }
@Override @Override

View File

@ -40,7 +40,7 @@ final class CompressedLargeMessageControllerImpl implements LargeMessageControll
private final LargeMessageController bufferDelegate; private final LargeMessageController bufferDelegate;
public CompressedLargeMessageControllerImpl(final LargeMessageController bufferDelegate) { CompressedLargeMessageControllerImpl(final LargeMessageController bufferDelegate) {
this.bufferDelegate = bufferDelegate; this.bufferDelegate = bufferDelegate;
} }

View File

@ -1141,7 +1141,7 @@ public class LargeMessageControllerImpl implements LargeMessageController {
private final class FileCache { private final class FileCache {
public FileCache(final File cachedFile) { private FileCache(final File cachedFile) {
this.cachedFile = cachedFile; this.cachedFile = cachedFile;
} }
@ -1323,13 +1323,13 @@ public class LargeMessageControllerImpl implements LargeMessageController {
final int flowControlSize; final int flowControlSize;
final boolean continues; final boolean continues;
public LargeData() { private LargeData() {
continues = false; continues = false;
flowControlSize = 0; flowControlSize = 0;
chunk = null; chunk = null;
} }
public LargeData(byte[] chunk, int flowControlSize, boolean continues) { private LargeData(byte[] chunk, int flowControlSize, boolean continues) {
this.chunk = chunk; this.chunk = chunk;
this.flowControlSize = flowControlSize; this.flowControlSize = flowControlSize;
this.continues = continues; this.continues = continues;

View File

@ -1784,7 +1784,7 @@ public final class ServerLocatorImpl implements ServerLocatorInternal, Discovery
private volatile ClientSessionFactoryInternal factory; private volatile ClientSessionFactoryInternal factory;
public Connector(TransportConfiguration initialConnector, ClientSessionFactoryInternal factory) { private Connector(TransportConfiguration initialConnector, ClientSessionFactoryInternal factory) {
this.initialConnector = initialConnector; this.initialConnector = initialConnector;
this.factory = factory; this.factory = factory;
} }

View File

@ -1013,7 +1013,7 @@ public abstract class MessageImpl implements MessageInternal {
private int lastPos = 0; private int lastPos = 0;
public DecodingContext() { private DecodingContext() {
} }
@Override @Override

View File

@ -725,7 +725,7 @@ public class NettyConnector extends AbstractConnector {
private final CountDownLatch latch = new CountDownLatch(1); private final CountDownLatch latch = new CountDownLatch(1);
private boolean handshakeComplete = false; private boolean handshakeComplete = false;
public HttpUpgradeHandler(ChannelPipeline pipeline, HttpClientCodec httpClientCodec) { private HttpUpgradeHandler(ChannelPipeline pipeline, HttpClientCodec httpClientCodec) {
this.pipeline = pipeline; this.pipeline = pipeline;
this.httpClientCodec = httpClientCodec; this.httpClientCodec = httpClientCodec;
} }
@ -798,7 +798,7 @@ public class NettyConnector extends AbstractConnector {
private String cookie; private String cookie;
public HttpHandler() throws Exception { HttpHandler() throws Exception {
url = new URI("http", null, host, port, servletPath, null, null).toString(); url = new URI("http", null, host, port, servletPath, null, null).toString();
} }

View File

@ -74,7 +74,7 @@ public final class OrderedExecutorFactory implements ExecutorFactory {
private static final int STATE_NOT_RUNNING = 0; private static final int STATE_NOT_RUNNING = 0;
private static final int STATE_RUNNING = 1; private static final int STATE_RUNNING = 1;
public OrderedExecutor(Executor delegate) { private OrderedExecutor(Executor delegate) {
this.delegate = delegate; this.delegate = delegate;
} }

View File

@ -342,7 +342,7 @@ public class SoftValueHashMap<K, V extends SoftValueHashMap.ValueCache> implemen
used = usedCounter.incrementAndGet(); used = usedCounter.incrementAndGet();
} }
public AggregatedSoftReference(final K key, final V referent) { AggregatedSoftReference(final K key, final V referent) {
super(referent, refQueue); super(referent, refQueue);
this.key = key; this.key = key;
} }

View File

@ -42,7 +42,7 @@ public class XmlUtil {
static final Pattern pattern = Pattern.compile("\\$\\{([^\\}]+)\\}"); static final Pattern pattern = Pattern.compile("\\$\\{([^\\}]+)\\}");
private final Properties props; private final Properties props;
public PropertiesFilter(XMLStreamReader parent, Properties props) { PropertiesFilter(XMLStreamReader parent, Properties props) {
super(parent); super(parent);
this.props = props; this.props = props;
} }

View File

@ -24,7 +24,7 @@ import org.apache.activemq.artemis.core.journal.RecordInfo;
final class TransactionHolder { final class TransactionHolder {
public TransactionHolder(final long id) { TransactionHolder(final long id) {
transactionID = id; transactionID = id;
} }

View File

@ -169,7 +169,7 @@ public class JDBCSequentialFileFactoryTest {
private final CountDownLatch countDownLatch; private final CountDownLatch countDownLatch;
public IOCallbackCountdown(int size) { private IOCallbackCountdown(int size) {
this.countDownLatch = new CountDownLatch(size); this.countDownLatch = new CountDownLatch(size);
} }

View File

@ -143,7 +143,7 @@ public class ActiveMQJMSConsumer implements JMSConsumer {
private final MessageListener wrapped; private final MessageListener wrapped;
public MessageListenerWrapper(MessageListener wrapped) { MessageListenerWrapper(MessageListener wrapped) {
this.wrapped = wrapped; this.wrapped = wrapped;
} }

View File

@ -628,7 +628,7 @@ public final class ActiveMQJMSProducer implements JMSProducer {
private final CompletionListener wrapped; private final CompletionListener wrapped;
public CompletionListenerWrapper(CompletionListener wrapped) { CompletionListenerWrapper(CompletionListener wrapped) {
this.wrapped = wrapped; this.wrapped = wrapped;
} }

View File

@ -533,7 +533,7 @@ public class ActiveMQMessageProducer implements MessageProducer, QueueSender, To
* @param jmsMessage * @param jmsMessage
* @param producer * @param producer
*/ */
public CompletionListenerWrapper(CompletionListener listener, private CompletionListenerWrapper(CompletionListener listener,
Message jmsMessage, Message jmsMessage,
ActiveMQMessageProducer producer) { ActiveMQMessageProducer producer) {
this.completionListener = listener; this.completionListener = listener;

View File

@ -1900,7 +1900,7 @@ public final class JMSBridgeImpl implements JMSBridge {
BridgeFailoverListener failoverListener; BridgeFailoverListener failoverListener;
private final boolean isSource; private final boolean isSource;
public BridgeExceptionListener(boolean ha, BridgeFailoverListener failoverListener, boolean isSource) { private BridgeExceptionListener(boolean ha, BridgeFailoverListener failoverListener, boolean isSource) {
this.ha = ha; this.ha = ha;
this.failoverListener = failoverListener; this.failoverListener = failoverListener;
this.isSource = isSource; this.isSource = isSource;
@ -1992,7 +1992,7 @@ public final class JMSBridgeImpl implements JMSBridge {
private final boolean isSource; private final boolean isSource;
volatile FailoverEventType lastEvent; volatile FailoverEventType lastEvent;
public BridgeFailoverListener(boolean isSource) { private BridgeFailoverListener(boolean isSource) {
this.isSource = isSource; this.isSource = isSource;
} }

View File

@ -31,7 +31,7 @@ public enum JMSNotificationType implements NotificationType {
private int type; private int type;
private JMSNotificationType(int type) { JMSNotificationType(int type) {
this.type = type; this.type = type;
} }

View File

@ -359,7 +359,7 @@ public final class AIOSequentialFileFactory extends AbstractSequentialFileFactor
private class PollerThread extends Thread { private class PollerThread extends Thread {
public PollerThread() { private PollerThread() {
super("Apache ActiveMQ Artemis libaio poller"); super("Apache ActiveMQ Artemis libaio poller");
} }

View File

@ -28,7 +28,7 @@ abstract class JournalBase implements Journal {
protected final int fileSize; protected final int fileSize;
private final boolean supportsCallback; private final boolean supportsCallback;
public JournalBase(boolean supportsCallback, int fileSize) { JournalBase(boolean supportsCallback, int fileSize) {
if (fileSize < JournalImpl.MIN_FILE_SIZE) { if (fileSize < JournalImpl.MIN_FILE_SIZE) {
throw new IllegalArgumentException("File size cannot be less than " + JournalImpl.MIN_FILE_SIZE + " bytes"); throw new IllegalArgumentException("File size cannot be less than " + JournalImpl.MIN_FILE_SIZE + " bytes");
} }

View File

@ -444,7 +444,7 @@ public class JournalCompactor extends AbstractJournalUpdateTask implements Journ
JournalFile usedFile; JournalFile usedFile;
public DeleteCompactCommand(final long id, final JournalFile usedFile) { private DeleteCompactCommand(final long id, final JournalFile usedFile) {
this.id = id; this.id = id;
this.usedFile = usedFile; this.usedFile = usedFile;
} }
@ -479,7 +479,7 @@ public class JournalCompactor extends AbstractJournalUpdateTask implements Journ
private final int size; private final int size;
public UpdateCompactCommand(final long id, final JournalFile usedFile, final int size) { private UpdateCompactCommand(final long id, final JournalFile usedFile, final int size) {
this.id = id; this.id = id;
this.usedFile = usedFile; this.usedFile = usedFile;
this.size = size; this.size = size;
@ -501,7 +501,7 @@ public class JournalCompactor extends AbstractJournalUpdateTask implements Journ
*/ */
private final JournalFile commitFile; private final JournalFile commitFile;
public CommitCompactCommand(final JournalTransaction liveTransaction, final JournalFile commitFile) { private CommitCompactCommand(final JournalTransaction liveTransaction, final JournalFile commitFile) {
this.liveTransaction = liveTransaction; this.liveTransaction = liveTransaction;
this.commitFile = commitFile; this.commitFile = commitFile;
} }
@ -526,7 +526,7 @@ public class JournalCompactor extends AbstractJournalUpdateTask implements Journ
*/ */
private final JournalFile rollbackFile; private final JournalFile rollbackFile;
public RollbackCompactCommand(final JournalTransaction liveTransaction, final JournalFile rollbackFile) { private RollbackCompactCommand(final JournalTransaction liveTransaction, final JournalFile rollbackFile) {
this.liveTransaction = liveTransaction; this.liveTransaction = liveTransaction;
this.rollbackFile = rollbackFile; this.rollbackFile = rollbackFile;
} }

View File

@ -2578,7 +2578,7 @@ public class JournalImpl extends JournalBase implements TestableJournal, Journal
// Used on Load // Used on Load
private static final class TransactionHolder { private static final class TransactionHolder {
public TransactionHolder(final long id) { private TransactionHolder(final long id) {
transactionID = id; transactionID = id;
} }

View File

@ -721,7 +721,7 @@ public class LibaioTest {
String errorMessage; String errorMessage;
int errno; int errno;
public TestInfo() { TestInfo() {
count.incrementAndGet(); count.incrementAndGet();
} }

View File

@ -43,7 +43,7 @@ class MQTTProtocolManager implements ProtocolManager, NotificationListener {
private MQTTLogger log = MQTTLogger.LOGGER; private MQTTLogger log = MQTTLogger.LOGGER;
public MQTTProtocolManager(ActiveMQServer server) { MQTTProtocolManager(ActiveMQServer server) {
this.server = server; this.server = server;
} }

View File

@ -23,7 +23,7 @@ public class CreditsSemaphore {
@SuppressWarnings("serial") @SuppressWarnings("serial")
private static class Sync extends AbstractQueuedSynchronizer { private static class Sync extends AbstractQueuedSynchronizer {
public Sync(int initial) { private Sync(int initial) {
setState(initial); setState(initial);
} }

View File

@ -38,7 +38,7 @@ public class ReusableLatch {
@SuppressWarnings("serial") @SuppressWarnings("serial")
private static class CountSync extends AbstractQueuedSynchronizer { private static class CountSync extends AbstractQueuedSynchronizer {
public CountSync(int count) { private CountSync(int count) {
setState(count); setState(count);
} }

View File

@ -50,7 +50,7 @@ public class AbstractConnectionContextTest {
private class TestConnectionContext extends AbstractConnectionContext { private class TestConnectionContext extends AbstractConnectionContext {
public TestConnectionContext(AMQPConnectionCallback connectionCallback) { private TestConnectionContext(AMQPConnectionCallback connectionCallback) {
super(connectionCallback, Executors.newSingleThreadExecutor(ActiveMQThreadFactory.defaultThreadFactory()), null); super(connectionCallback, Executors.newSingleThreadExecutor(ActiveMQThreadFactory.defaultThreadFactory()), null);
} }

View File

@ -120,7 +120,7 @@ public class MinimalServer {
AMQPServerConnectionContext connection; AMQPServerConnectionContext connection;
public ProtocolDecoder() { ProtocolDecoder() {
} }
@Override @Override

View File

@ -97,7 +97,7 @@ public class ActiveMQStompException extends Exception {
public final String key; public final String key;
public final String val; public final String val;
public Header(String key, String val) { private Header(String key, String val) {
this.key = key; this.key = key;
this.val = val; this.val = val;
} }

View File

@ -75,7 +75,7 @@ class StompProtocolManager implements ProtocolManager<StompFrameInterceptor> {
// Constructors -------------------------------------------------- // Constructors --------------------------------------------------
public StompProtocolManager(final StompProtocolManagerFactory factory, StompProtocolManager(final StompProtocolManagerFactory factory,
final ActiveMQServer server, final ActiveMQServer server,
final List<StompFrameInterceptor> incomingInterceptors, final List<StompFrameInterceptor> incomingInterceptors,
final List<StompFrameInterceptor> outgoingInterceptors) { final List<StompFrameInterceptor> outgoingInterceptors) {

View File

@ -26,7 +26,7 @@ public enum StompVersions {
private String version; private String version;
private StompVersions(String ver) { StompVersions(String ver) {
this.version = ver; this.version = ver;
} }

View File

@ -251,7 +251,7 @@ public class StompFrameHandlerV11 extends VersionedStompFrameHandler implements
AtomicLong lastAccepted = new AtomicLong(0); AtomicLong lastAccepted = new AtomicLong(0);
StompFrame pingFrame; StompFrame pingFrame;
public HeartBeater(long clientPing, long clientAcceptPing) { private HeartBeater(long clientPing, long clientAcceptPing) {
if (clientPing != 0) { if (clientPing != 0) {
serverAcceptPing = clientPing > MIN_CLIENT_PING ? clientPing : MIN_CLIENT_PING; serverAcceptPing = clientPing > MIN_CLIENT_PING ? clientPing : MIN_CLIENT_PING;
} }

View File

@ -150,7 +150,7 @@ public class AutoAckTopicTest extends MessageTestBase {
private boolean isFinished = false; private boolean isFinished = false;
private boolean failed = false; private boolean failed = false;
public NewPullSubscriber(String url) { private NewPullSubscriber(String url) {
this.url = url; this.url = url;
} }
@ -187,7 +187,7 @@ public class AutoAckTopicTest extends MessageTestBase {
private boolean isFinished = false; private boolean isFinished = false;
private boolean failed = false; private boolean failed = false;
public AcceptWaitListener(String url) { private AcceptWaitListener(String url) {
this.url = url; this.url = url;
} }

View File

@ -79,7 +79,7 @@ public abstract class ComparisonExpression extends BinaryExpression implements B
/** /**
*/ */
public LikeExpression(Expression right, String like, int escape) { LikeExpression(Expression right, String like, int escape) {
super(right); super(right);
StringBuffer regexp = new StringBuffer(like.length() * 2); StringBuffer regexp = new StringBuffer(like.length() * 2);

View File

@ -27,7 +27,7 @@ public class ConstantExpression implements Expression {
static class BooleanConstantExpression extends ConstantExpression implements BooleanExpression { static class BooleanConstantExpression extends ConstantExpression implements BooleanExpression {
public BooleanConstantExpression(Object value) { BooleanConstantExpression(Object value) {
super(value); super(value);
} }

View File

@ -125,7 +125,7 @@ public abstract class UnaryExpression implements Expression {
abstract static class BooleanUnaryExpression extends UnaryExpression implements BooleanExpression { abstract static class BooleanUnaryExpression extends UnaryExpression implements BooleanExpression {
public BooleanUnaryExpression(Expression left) { BooleanUnaryExpression(Expression left) {
super(left); super(left);
} }

View File

@ -64,7 +64,7 @@ public class ProtocolTrackerTest {
ServiceReference<ProtocolManagerFactory<Interceptor>> ref; ServiceReference<ProtocolManagerFactory<Interceptor>> ref;
ProtocolManagerFactory factory; ProtocolManagerFactory factory;
public RefFact(IMocksControl c, BundleContext context, String[] protocols) { RefFact(IMocksControl c, BundleContext context, String[] protocols) {
ref = c.createMock(ServiceReference.class); ref = c.createMock(ServiceReference.class);
factory = c.createMock(ProtocolManagerFactory.class); factory = c.createMock(ProtocolManagerFactory.class);
expect(factory.getProtocols()).andReturn(protocols).atLeastOnce(); expect(factory.getProtocols()).andReturn(protocols).atLeastOnce();

View File

@ -20,7 +20,7 @@ import java.io.Serializable;
public interface HAPolicyConfiguration extends Serializable { public interface HAPolicyConfiguration extends Serializable {
public enum TYPE { enum TYPE {
LIVE_ONLY, LIVE_ONLY,
REPLICATED, REPLICATED,
REPLICA, REPLICA,

View File

@ -20,7 +20,7 @@ import java.io.Serializable;
public interface StoreConfiguration extends Serializable { public interface StoreConfiguration extends Serializable {
public enum StoreType { enum StoreType {
FILE, FILE,
DATABASE DATABASE
} }

View File

@ -172,7 +172,7 @@ public class FilterImpl implements Filter {
private final ServerMessage message; private final ServerMessage message;
public FilterableServerMessage(ServerMessage message) { private FilterableServerMessage(ServerMessage message) {
this.message = message; this.message = message;
} }

View File

@ -37,7 +37,7 @@ class PageCacheImpl implements PageCache {
// Constructors -------------------------------------------------- // Constructors --------------------------------------------------
public PageCacheImpl(final Page page) { PageCacheImpl(final Page page) {
this.page = page; this.page = page;
} }

View File

@ -351,7 +351,7 @@ public class PageSubscriptionCounterImpl implements PageSubscriptionCounter {
private static class ItemOper { private static class ItemOper {
public ItemOper(PageSubscriptionCounterImpl counter, long id, int add) { private ItemOper(PageSubscriptionCounterImpl counter, long id, int add) {
this.counter = counter; this.counter = counter;
this.id = id; this.id = id;
this.amount = add; this.amount = add;

View File

@ -942,7 +942,7 @@ final class PageSubscriptionImpl implements PageSubscription {
} }
} }
public PageCursorInfo(final long pageId, final int numberOfMessages, final PageCache cache) { private PageCursorInfo(final long pageId, final int numberOfMessages, final PageCache cache) {
logger.tracef("Created PageCursorInfo for pageNr=%d, numberOfMessages=%d, cache=%s", pageId, numberOfMessages, cache); logger.tracef("Created PageCursorInfo for pageNr=%d, numberOfMessages=%d, cache=%s", pageId, numberOfMessages, cache);
this.pageId = pageId; this.pageId = pageId;
this.numberOfMessages = numberOfMessages; this.numberOfMessages = numberOfMessages;
@ -1130,7 +1130,7 @@ final class PageSubscriptionImpl implements PageSubscription {
*/ */
private volatile PagedReference cachedNext; private volatile PagedReference cachedNext;
public CursorIterator() { private CursorIterator() {
} }
@Override @Override

View File

@ -303,7 +303,7 @@ public final class PageTransactionInfoImpl implements PageTransactionInfo {
final PagePosition pagePosition; final PagePosition pagePosition;
final PageIterator iterator; final PageIterator iterator;
public LateDelivery(PageSubscription subscription, PagePosition pagePosition, PageIterator iterator) { private LateDelivery(PageSubscription subscription, PagePosition pagePosition, PageIterator iterator) {
this.subscription = subscription; this.subscription = subscription;
this.pagePosition = pagePosition; this.pagePosition = pagePosition;
this.iterator = iterator; this.iterator = iterator;
@ -332,7 +332,7 @@ public final class PageTransactionInfoImpl implements PageTransactionInfo {
private final PagingManager pagingManager; private final PagingManager pagingManager;
public UpdatePageTXOperation(final StorageManager storageManager, final PagingManager pagingManager) { private UpdatePageTXOperation(final StorageManager storageManager, final PagingManager pagingManager) {
this.storageManager = storageManager; this.storageManager = storageManager;
this.pagingManager = pagingManager; this.pagingManager = pagingManager;
} }

View File

@ -937,7 +937,7 @@ public class PagingStoreImpl implements PagingStore {
this.usedStores.add(store); this.usedStores.add(store);
} }
public FinishPageMessageOperation(final PageTransactionInfo pageTransaction, private FinishPageMessageOperation(final PageTransactionInfo pageTransaction,
final StorageManager storageManager, final StorageManager storageManager,
final PagingManager pagingManager) { final PagingManager pagingManager) {
this.pageTransaction = pageTransaction; this.pageTransaction = pageTransaction;

View File

@ -223,7 +223,7 @@ public interface StorageManager extends IDGenerator, ActiveMQComponent {
DURABLE(".msg"), TEMPORARY(".tmp"), SYNC(".sync"); DURABLE(".msg"), TEMPORARY(".tmp"), SYNC(".sync");
final String extension; final String extension;
private LargeMessageExtension(String extension) { LargeMessageExtension(String extension) {
this.extension = extension; this.extension = extension;
} }

View File

@ -24,11 +24,11 @@ import org.apache.activemq.artemis.core.server.impl.ServerMessageImpl;
class NullStorageLargeServerMessage extends ServerMessageImpl implements LargeServerMessage { class NullStorageLargeServerMessage extends ServerMessageImpl implements LargeServerMessage {
public NullStorageLargeServerMessage() { NullStorageLargeServerMessage() {
super(); super();
} }
public NullStorageLargeServerMessage(NullStorageLargeServerMessage other) { NullStorageLargeServerMessage(NullStorageLargeServerMessage other) {
super(other); super(other);
} }

View File

@ -94,7 +94,7 @@ public class ProtocolHandler {
private final boolean httpEnabled; private final boolean httpEnabled;
public ProtocolDecoder(boolean http, boolean httpEnabled) { ProtocolDecoder(boolean http, boolean httpEnabled) {
this.http = http; this.http = http;
this.httpEnabled = httpEnabled; this.httpEnabled = httpEnabled;
} }

View File

@ -204,7 +204,7 @@ public class CoreProtocolManager implements ProtocolManager<Interceptor> {
private final Acceptor acceptorUsed; private final Acceptor acceptorUsed;
private final CoreRemotingConnection rc; private final CoreRemotingConnection rc;
public LocalChannelHandler(final Configuration config, private LocalChannelHandler(final Configuration config,
final ConnectionEntry entry, final ConnectionEntry entry,
final Channel channel0, final Channel channel0,
final Acceptor acceptorUsed, final Acceptor acceptorUsed,

View File

@ -36,7 +36,7 @@ public final class BackupReplicationStartFailedMessage extends PacketImpl {
final int code; final int code;
private BackupRegistrationProblem(int code) { BackupRegistrationProblem(int code) {
this.code = code; this.code = code;
} }

View File

@ -39,7 +39,7 @@ public final class ReplicationLiveIsStoppingMessage extends PacketImpl {
FAIL_OVER(1); FAIL_OVER(1);
private final int code; private final int code;
private LiveStopping(int code) { LiveStopping(int code) {
this.code = code; this.code = code;
} }
} }

View File

@ -46,7 +46,7 @@ public class ReplicationStartSyncMessage extends PacketImpl {
private byte code; private byte code;
private SyncDataType(byte code) { SyncDataType(byte code) {
this.code = code; this.code = code;
} }

View File

@ -53,7 +53,7 @@ public final class ReplicationSyncFileMessage extends PacketImpl {
private byte code; private byte code;
private static final Set<FileType> ALL_OF = EnumSet.allOf(FileType.class); private static final Set<FileType> ALL_OF = EnumSet.allOf(FileType.class);
private FileType(int code) { FileType(int code) {
this.code = (byte) code; this.code = (byte) code;
} }

View File

@ -123,13 +123,13 @@ public class HttpAcceptorHandler extends ChannelDuplexHandler {
private final ChannelPromise promise; private final ChannelPromise promise;
public ResponseRunner(final ByteBuf buffer, ChannelPromise promise) { ResponseRunner(final ByteBuf buffer, ChannelPromise promise) {
this.buffer = buffer; this.buffer = buffer;
bogusResponse = false; bogusResponse = false;
this.promise = promise; this.promise = promise;
} }
public ResponseRunner() { ResponseRunner() {
bogusResponse = true; bogusResponse = true;
buffer = Unpooled.buffer(0); buffer = Unpooled.buffer(0);
promise = channel.newPromise(); promise = channel.newPromise();
@ -211,7 +211,7 @@ public class HttpAcceptorHandler extends ChannelDuplexHandler {
final long timeReceived; final long timeReceived;
public ResponseHolder(final long timeReceived, final FullHttpResponse response) { private ResponseHolder(final long timeReceived, final FullHttpResponse response) {
this.timeReceived = timeReceived; this.timeReceived = timeReceived;
this.response = response; this.response = response;
} }

View File

@ -186,7 +186,7 @@ public class BackupManager implements ActiveMQComponent {
private boolean announcingBackup; private boolean announcingBackup;
private boolean backupAnnounced = false; private boolean backupAnnounced = false;
public BackupConnector(String name, private BackupConnector(String name,
TransportConfiguration connector, TransportConfiguration connector,
long retryInterval, long retryInterval,
ClusterManager clusterManager) { ClusterManager clusterManager) {
@ -328,7 +328,7 @@ public class BackupManager implements ActiveMQComponent {
private final TransportConfiguration[] tcConfigs; private final TransportConfiguration[] tcConfigs;
public StaticBackupConnector(TransportConfiguration[] tcConfigs, private StaticBackupConnector(TransportConfiguration[] tcConfigs,
String name, String name,
TransportConfiguration connector, TransportConfiguration connector,
long retryInterval, long retryInterval,
@ -365,7 +365,7 @@ public class BackupManager implements ActiveMQComponent {
private final DiscoveryGroupConfiguration discoveryGroupConfiguration; private final DiscoveryGroupConfiguration discoveryGroupConfiguration;
public DiscoveryBackupConnector(DiscoveryGroupConfiguration discoveryGroupConfiguration, private DiscoveryBackupConnector(DiscoveryGroupConfiguration discoveryGroupConfiguration,
String name, String name,
TransportConfiguration connector, TransportConfiguration connector,
long retryInterval, long retryInterval,

View File

@ -306,7 +306,7 @@ public class ClusterController implements ActiveMQComponent {
private final ChannelHandler channelHandler; private final ChannelHandler channelHandler;
boolean authorized = false; boolean authorized = false;
public ClusterControllerChannelHandler(Channel clusterChannel, private ClusterControllerChannelHandler(Channel clusterChannel,
Acceptor acceptorUsed, Acceptor acceptorUsed,
CoreRemotingConnection remotingConnection, CoreRemotingConnection remotingConnection,
ChannelHandler channelHandler) { ChannelHandler channelHandler) {
@ -396,7 +396,7 @@ public class ClusterController implements ActiveMQComponent {
private ServerLocatorInternal serverLocator; private ServerLocatorInternal serverLocator;
public ConnectRunnable(ServerLocatorInternal serverLocator) { private ConnectRunnable(ServerLocatorInternal serverLocator) {
this.serverLocator = serverLocator; this.serverLocator = serverLocator;
} }

View File

@ -1055,7 +1055,7 @@ public class BridgeImpl implements Bridge, SessionFailureListener, SendAcknowled
private final Executor executor; private final Executor executor;
public FutureConnectRunnable(Executor exe, BridgeImpl bridge) { private FutureConnectRunnable(Executor exe, BridgeImpl bridge) {
executor = exe; executor = exe;
this.bridge = bridge; this.bridge = bridge;
} }
@ -1071,7 +1071,7 @@ public class BridgeImpl implements Bridge, SessionFailureListener, SendAcknowled
private final BridgeImpl bridge; private final BridgeImpl bridge;
public ConnectRunnable(BridgeImpl bridge2) { private ConnectRunnable(BridgeImpl bridge2) {
bridge = bridge2; bridge = bridge2;
} }

View File

@ -835,7 +835,7 @@ public final class ClusterConnectionImpl implements ClusterConnection, AfterConn
private volatile boolean reset = false; private volatile boolean reset = false;
public MessageFlowRecordImpl(final ServerLocatorInternal targetLocator, private MessageFlowRecordImpl(final ServerLocatorInternal targetLocator,
final long eventUID, final long eventUID,
final String targetNodeID, final String targetNodeID,
final TransportConfiguration connector, final TransportConfiguration connector,
@ -1418,7 +1418,7 @@ public final class ClusterConnectionImpl implements ClusterConnection, AfterConn
private final TransportConfiguration[] tcConfigs; private final TransportConfiguration[] tcConfigs;
public StaticClusterConnector(TransportConfiguration[] tcConfigs) { private StaticClusterConnector(TransportConfiguration[] tcConfigs) {
this.tcConfigs = tcConfigs; this.tcConfigs = tcConfigs;
} }
@ -1446,7 +1446,7 @@ public final class ClusterConnectionImpl implements ClusterConnection, AfterConn
private final DiscoveryGroupConfiguration dg; private final DiscoveryGroupConfiguration dg;
public DiscoveryClusterConnector(DiscoveryGroupConfiguration dg) { private DiscoveryClusterConnector(DiscoveryGroupConfiguration dg) {
this.dg = dg; this.dg = dg;
} }

View File

@ -257,7 +257,7 @@ public final class QuorumManager implements ClusterTopologyListener, ActiveMQCom
private final List<VoteRunnable> runnables; private final List<VoteRunnable> runnables;
private int size; private int size;
public VoteRunnableHolder(QuorumVote quorumVote, List<VoteRunnable> runnables, int size) { private VoteRunnableHolder(QuorumVote quorumVote, List<VoteRunnable> runnables, int size) {
this.quorumVote = quorumVote; this.quorumVote = quorumVote;
this.runnables = runnables; this.runnables = runnables;
@ -282,7 +282,7 @@ public final class QuorumManager implements ClusterTopologyListener, ActiveMQCom
private final QuorumVote quorumVote; private final QuorumVote quorumVote;
private ClusterControl clusterControl; private ClusterControl clusterControl;
public VoteRunnable(TransportConfiguration serverTC, QuorumVote quorumVote) { private VoteRunnable(TransportConfiguration serverTC, QuorumVote quorumVote) {
this.serverTC = serverTC; this.serverTC = serverTC;
this.quorumVote = quorumVote; this.quorumVote = quorumVote;
} }

View File

@ -32,7 +32,7 @@ final class BackupTopologyListener implements ClusterTopologyListener {
// Transport configuration of this node // Transport configuration of this node
private final TransportConfiguration myTc; private final TransportConfiguration myTc;
public BackupTopologyListener(String ownId, TransportConfiguration nodeTransportConfig) { BackupTopologyListener(String ownId, TransportConfiguration nodeTransportConfig) {
this.ownId = ownId; this.ownId = ownId;
this.myTc = nodeTransportConfig; this.myTc = nodeTransportConfig;
} }

View File

@ -169,7 +169,7 @@ public class ColocatedActivation extends LiveActivation {
//the available nodes that we can request //the available nodes that we can request
private final List<Pair<String, Integer>> nodes = new ArrayList<>(); private final List<Pair<String, Integer>> nodes = new ArrayList<>();
public RequestBackupQuorumVote() { private RequestBackupQuorumVote() {
super(REQUEST_BACKUP_QUORUM_VOTE); super(REQUEST_BACKUP_QUORUM_VOTE);
} }
@ -249,11 +249,11 @@ public class ColocatedActivation extends LiveActivation {
private String nodeID; private String nodeID;
private boolean backupAvailable; private boolean backupAvailable;
public RequestBackupVote() { RequestBackupVote() {
backupsSize = -1; backupsSize = -1;
} }
public RequestBackupVote(int backupsSize, String nodeID, boolean backupAvailable) { RequestBackupVote(int backupsSize, String nodeID, boolean backupAvailable) {
this.backupsSize = backupsSize; this.backupsSize = backupsSize;
this.nodeID = nodeID; this.nodeID = nodeID;
this.backupAvailable = backupAvailable; this.backupAvailable = backupAvailable;

View File

@ -2708,7 +2708,7 @@ public class QueueImpl implements Queue {
final boolean scheduleExpiry; final boolean scheduleExpiry;
public DepageRunner(boolean scheduleExpiry) { private DepageRunner(boolean scheduleExpiry) {
this.scheduleExpiry = scheduleExpiry; this.scheduleExpiry = scheduleExpiry;
} }
@ -2785,7 +2785,7 @@ public class QueueImpl implements Queue {
Iterator lastIterator = null; Iterator lastIterator = null;
public TotalQueueIterator() { private TotalQueueIterator() {
if (pageSubscription != null) { if (pageSubscription != null) {
pageIter = pageSubscription.iterator(); pageIter = pageSubscription.iterator();
} }
@ -2911,7 +2911,7 @@ public class QueueImpl implements Queue {
private float threshold; private float threshold;
private long checkPeriod; private long checkPeriod;
public SlowConsumerReaperRunnable(long checkPeriod, float threshold, SlowConsumerPolicy policy) { private SlowConsumerReaperRunnable(long checkPeriod, float threshold, SlowConsumerPolicy policy) {
this.checkPeriod = checkPeriod; this.checkPeriod = checkPeriod;
this.policy = policy; this.policy = policy;
this.threshold = threshold; this.threshold = threshold;

View File

@ -39,7 +39,7 @@ final class ReplicationError implements Interceptor {
private final ActiveMQServer server; private final ActiveMQServer server;
private LiveNodeLocator nodeLocator; private LiveNodeLocator nodeLocator;
public ReplicationError(ActiveMQServer server, LiveNodeLocator nodeLocator) { ReplicationError(ActiveMQServer server, LiveNodeLocator nodeLocator) {
this.server = server; this.server = server;
this.nodeLocator = nodeLocator; this.nodeLocator = nodeLocator;
} }

View File

@ -165,7 +165,7 @@ public class ScheduledDeliveryHandlerImpl implements ScheduledDeliveryHandler {
long deliveryTime; long deliveryTime;
public ScheduledDeliveryRunnable(final long deliveryTime) { private ScheduledDeliveryRunnable(final long deliveryTime) {
this.deliveryTime = deliveryTime; this.deliveryTime = deliveryTime;
} }

View File

@ -1094,7 +1094,7 @@ public class ServerConsumerImpl implements ServerConsumer, ReadyListener {
private BodyEncoder context; private BodyEncoder context;
public LargeMessageDeliverer(final LargeServerMessage message, final MessageReference ref) throws Exception { private LargeMessageDeliverer(final LargeServerMessage message, final MessageReference ref) throws Exception {
largeMessage = message; largeMessage = message;
largeMessage.incrementDelayDeletionCount(); largeMessage.incrementDelayDeletionCount();

View File

@ -363,7 +363,7 @@ public class SharedNothingLiveActivation extends LiveActivation {
private final SimpleString nodeId; private final SimpleString nodeId;
private final CountDownLatch latch = new CountDownLatch(1); private final CountDownLatch latch = new CountDownLatch(1);
public NodeIdListener(SimpleString nodeId) { NodeIdListener(SimpleString nodeId) {
this.nodeId = nodeId; this.nodeId = nodeId;
} }

View File

@ -29,7 +29,7 @@ import org.apache.activemq.artemis.core.server.impl.RefsOperation;
*/ */
public interface Transaction { public interface Transaction {
static enum State { enum State {
ACTIVE, PREPARED, COMMITTED, ROLLEDBACK, SUSPENDED, ROLLBACK_ONLY ACTIVE, PREPARED, COMMITTED, ROLLEDBACK, SUSPENDED, ROLLBACK_ONLY
} }

View File

@ -242,7 +242,7 @@ public class ResourceManagerImpl implements ResourceManager {
public final long recordID; public final long recordID;
public HeuristicCompletionHolder(final long recordID, final Xid xid, final boolean isCommit) { private HeuristicCompletionHolder(final long recordID, final Xid xid, final boolean isCommit) {
this.recordID = recordID; this.recordID = recordID;
this.xid = xid; this.xid = xid;
this.isCommit = isCommit; this.isCommit = isCommit;

View File

@ -141,7 +141,7 @@ public class PropertiesLoginModuleTest extends Assert {
private final String user; private final String user;
private final String pass; private final String pass;
public UserPassHandler(final String user, final String pass) { private UserPassHandler(final String user, final String pass) {
this.user = user; this.user = user;
this.pass = pass; this.pass = pass;
} }

View File

@ -42,7 +42,7 @@ public class BroadcastGroupImplTest extends ActiveMQTestBase {
static class BroadcastEndpointImpl implements BroadcastEndpoint { static class BroadcastEndpointImpl implements BroadcastEndpoint {
private BroadcastEndpointFactoryImpl factory; private BroadcastEndpointFactoryImpl factory;
public BroadcastEndpointImpl(BroadcastEndpointFactoryImpl factory) { BroadcastEndpointImpl(BroadcastEndpointFactoryImpl factory) {
this.factory = factory; this.factory = factory;
} }

View File

@ -288,7 +288,7 @@ public class ScheduledDeliveryHandlerTest extends Assert {
final long id; final long id;
public FakeMessage(final long id) { FakeMessage(final long id) {
this.id = id; this.id = id;
} }

View File

@ -247,7 +247,7 @@ public class RepositoryTest extends ActiveMQTestBase {
return DummyMergeable.merged.contains(i); return DummyMergeable.merged.contains(i);
} }
public DummyMergeable(final Integer id) { DummyMergeable(final Integer id) {
this.id = id; this.id = id;
} }

View File

@ -1803,7 +1803,7 @@ public abstract class ActiveMQTestBase extends Assert {
/** /**
* @param recordsType * @param recordsType
*/ */
public RecordTypeCounter(HashMap<Integer, AtomicInteger> recordsType) { private RecordTypeCounter(HashMap<Integer, AtomicInteger> recordsType) {
this.recordsType = recordsType; this.recordsType = recordsType;
} }

View File

@ -99,7 +99,7 @@ public class WebServerComponentTest extends Assert {
private CountDownLatch latch; private CountDownLatch latch;
private String body; private String body;
public ClientHandler(CountDownLatch latch) { ClientHandler(CountDownLatch latch) {
this.latch = latch; this.latch = latch;
} }

View File

@ -361,7 +361,7 @@ public abstract class PerfBase {
private final AtomicLong count = new AtomicLong(0); private final AtomicLong count = new AtomicLong(0);
public PerfListener(final CountDownLatch countDownLatch, final PerfParams perfParams) { private PerfListener(final CountDownLatch countDownLatch, final PerfParams perfParams) {
this.countDownLatch = countDownLatch; this.countDownLatch = countDownLatch;
this.perfParams = perfParams; this.perfParams = perfParams;
warmingUp = perfParams.getNoOfWarmupMessages() > 0; warmingUp = perfParams.getNoOfWarmupMessages() > 0;

View File

@ -104,7 +104,7 @@ class SimpleMessageListener implements MessageListener {
private final String name; private final String name;
private final Map<String, String> messageReceiverMap; private final Map<String, String> messageReceiverMap;
public SimpleMessageListener(final String listenerName, Map<String, String> messageReceiverMap) { SimpleMessageListener(final String listenerName, Map<String, String> messageReceiverMap) {
name = listenerName; name = listenerName;
this.messageReceiverMap = messageReceiverMap; this.messageReceiverMap = messageReceiverMap;
} }

View File

@ -111,7 +111,7 @@ class SimpleMessageListener implements MessageListener {
private final String name; private final String name;
final Map<String, String> messageReceiverMap; final Map<String, String> messageReceiverMap;
public SimpleMessageListener(String listenerName, Map<String, String> messageReceiverMap) { SimpleMessageListener(String listenerName, Map<String, String> messageReceiverMap) {
name = listenerName; name = listenerName;
this.messageReceiverMap = messageReceiverMap; this.messageReceiverMap = messageReceiverMap;
} }

View File

@ -115,7 +115,7 @@ class SimpleMessageListener implements MessageListener {
ArrayList<TextMessage> msgReceived; ArrayList<TextMessage> msgReceived;
AtomicBoolean result; AtomicBoolean result;
public SimpleMessageListener(ArrayList<TextMessage> msgReceived, AtomicBoolean result) { SimpleMessageListener(ArrayList<TextMessage> msgReceived, AtomicBoolean result) {
this.msgReceived = msgReceived; this.msgReceived = msgReceived;
this.result = result; this.result = result;
} }

View File

@ -117,7 +117,7 @@ class SimpleMessageListener implements MessageListener {
private final String name; private final String name;
private AtomicBoolean result; private AtomicBoolean result;
public SimpleMessageListener(final String listener, AtomicBoolean result) { SimpleMessageListener(final String listener, AtomicBoolean result) {
name = listener; name = listener;
this.result = result; this.result = result;
} }

View File

@ -111,7 +111,7 @@ class SimpleMessageListener implements MessageListener {
private final String name; private final String name;
private AtomicBoolean result; private AtomicBoolean result;
public SimpleMessageListener(final String listener, AtomicBoolean result) { SimpleMessageListener(final String listener, AtomicBoolean result) {
name = listener; name = listener;
this.result = result; this.result = result;
} }

View File

@ -119,7 +119,7 @@ class SimpleMessageListener implements MessageListener {
private final String name; private final String name;
AtomicBoolean result; AtomicBoolean result;
public SimpleMessageListener(final String listener, AtomicBoolean result) { SimpleMessageListener(final String listener, AtomicBoolean result) {
name = listener; name = listener;
this.result = result; this.result = result;
} }

View File

@ -173,7 +173,7 @@ class SimpleMessageListener implements MessageListener {
ArrayList<String> receiveHolder; ArrayList<String> receiveHolder;
AtomicBoolean result; AtomicBoolean result;
public SimpleMessageListener(ArrayList<String> receiveHolder, AtomicBoolean result) { SimpleMessageListener(ArrayList<String> receiveHolder, AtomicBoolean result) {
this.receiveHolder = receiveHolder; this.receiveHolder = receiveHolder;
this.result = result; this.result = result;
} }

View File

@ -315,7 +315,7 @@ public class AeroGearConnectorService implements ConnectorService, Consumer, Mes
private int retryAttempt; private int retryAttempt;
public ReconnectRunnable(int retryAttempt) { private ReconnectRunnable(int retryAttempt) {
this.retryAttempt = retryAttempt; this.retryAttempt = retryAttempt;
} }

View File

@ -73,7 +73,7 @@ public class HierarchicalObjectRepositoryTest {
private final int code; private final int code;
public Clearer(int code) { private Clearer(int code) {
this.code = code; this.code = code;
} }

View File

@ -203,7 +203,7 @@ public class AeroGearBasicServerTest extends ActiveMQTestBase {
JSONObject jsonObject; JSONObject jsonObject;
private CountDownLatch latch; private CountDownLatch latch;
public AeroGearHandler(CountDownLatch latch) { AeroGearHandler(CountDownLatch latch) {
this.latch = latch; this.latch = latch;
} }

View File

@ -203,7 +203,7 @@ public class AutogroupIdTest extends ActiveMQTestBase {
private final CountDownLatch latch; private final CountDownLatch latch;
public MyMessageHandler(final CountDownLatch latch) { private MyMessageHandler(final CountDownLatch latch) {
this.latch = latch; this.latch = latch;
} }

View File

@ -242,7 +242,7 @@ public class CommitRollbackTest extends ActiveMQTestBase {
private final CountDownLatch latch; private final CountDownLatch latch;
public ackHandler(final ClientSession session, final CountDownLatch latch) { private ackHandler(final ClientSession session, final CountDownLatch latch) {
this.session = session; this.session = session;
this.latch = latch; this.latch = latch;
} }

View File

@ -175,7 +175,7 @@ public class DeadLetterAddressTest extends ActiveMQTestBase {
private final ClientSession clientSession; private final ClientSession clientSession;
public TestHandler(CountDownLatch latch, ClientSession clientSession) { TestHandler(CountDownLatch latch, ClientSession clientSession) {
this.latch = latch; this.latch = latch;
this.clientSession = clientSession; this.clientSession = clientSession;
} }

View File

@ -154,7 +154,7 @@ public class DeliveryOrderTest extends ActiveMQTestBase {
boolean failed = false; boolean failed = false;
public Receiver(final CountDownLatch latch) { Receiver(final CountDownLatch latch) {
this.latch = latch; this.latch = latch;
} }

View File

@ -215,7 +215,7 @@ public class HangConsumerTest extends ActiveMQTestBase {
* @param addressSettingsRepository * @param addressSettingsRepository
* @param executor * @param executor
*/ */
public MyQueueWithBlocking(final long id, MyQueueWithBlocking(final long id,
final SimpleString address, final SimpleString address,
final SimpleString name, final SimpleString name,
final Filter filter, final Filter filter,
@ -247,7 +247,7 @@ public class HangConsumerTest extends ActiveMQTestBase {
class LocalFactory extends QueueFactoryImpl { class LocalFactory extends QueueFactoryImpl {
public LocalFactory(final ExecutorFactory executorFactory, LocalFactory(final ExecutorFactory executorFactory,
final ScheduledExecutorService scheduledExecutor, final ScheduledExecutorService scheduledExecutor,
final HierarchicalRepository<AddressSettings> addressSettingsRepository, final HierarchicalRepository<AddressSettings> addressSettingsRepository,
final StorageManager storageManager) { final StorageManager storageManager) {
@ -567,7 +567,7 @@ public class HangConsumerTest extends ActiveMQTestBase {
class MyActiveMQServer extends ActiveMQServerImpl { class MyActiveMQServer extends ActiveMQServerImpl {
public MyActiveMQServer(Configuration configuration, MyActiveMQServer(Configuration configuration,
MBeanServer mbeanServer, MBeanServer mbeanServer,
ActiveMQSecurityManager securityManager) { ActiveMQSecurityManager securityManager) {
super(configuration, mbeanServer, securityManager); super(configuration, mbeanServer, securityManager);

View File

@ -513,7 +513,7 @@ public class InterruptedLargeMessageTest extends LargeMessageTestBase {
class NoPostACKQueue extends QueueImpl { class NoPostACKQueue extends QueueImpl {
public NoPostACKQueue(long id, NoPostACKQueue(long id,
SimpleString address, SimpleString address,
SimpleString name, SimpleString name,
Filter filter, Filter filter,
@ -552,7 +552,7 @@ public class InterruptedLargeMessageTest extends LargeMessageTestBase {
final ExecutorFactory execFactory; final ExecutorFactory execFactory;
public NoPostACKQueueFactory(StorageManager storageManager, NoPostACKQueueFactory(StorageManager storageManager,
PostOffice postOffice, PostOffice postOffice,
ScheduledExecutorService scheduledExecutor, ScheduledExecutorService scheduledExecutor,
HierarchicalRepository<AddressSettings> addressSettingsRepository, HierarchicalRepository<AddressSettings> addressSettingsRepository,

View File

@ -173,7 +173,7 @@ public class MessageConsumerRollbackTest extends ActiveMQTestBase {
CountDownLatch commitLatch; CountDownLatch commitLatch;
public LocalConsumer(AtomicInteger counter, CountDownLatch commitLatch) { private LocalConsumer(AtomicInteger counter, CountDownLatch commitLatch) {
this.counter = counter; this.counter = counter;
this.commitLatch = commitLatch; this.commitLatch = commitLatch;
} }

View File

@ -124,7 +124,7 @@ public class MessageGroupingConnectionFactoryTest extends ActiveMQTestBase {
private final boolean acknowledge; private final boolean acknowledge;
public DummyMessageHandler(final CountDownLatch latch, final boolean acknowledge) { private DummyMessageHandler(final CountDownLatch latch, final boolean acknowledge) {
this.latch = latch; this.latch = latch;
this.acknowledge = acknowledge; this.acknowledge = acknowledge;
} }

View File

@ -555,7 +555,7 @@ public class MessageGroupingTest extends ActiveMQTestBase {
private final boolean acknowledge; private final boolean acknowledge;
public DummyMessageHandler(final CountDownLatch latch, final boolean acknowledge) { private DummyMessageHandler(final CountDownLatch latch, final boolean acknowledge) {
this.latch = latch; this.latch = latch;
this.acknowledge = acknowledge; this.acknowledge = acknowledge;
} }

View File

@ -153,7 +153,7 @@ public class MessageHandlerTest extends ActiveMQTestBase {
private final CountDownLatch latch; private final CountDownLatch latch;
public MyHandler(final CountDownLatch latch) { MyHandler(final CountDownLatch latch) {
this.latch = latch; this.latch = latch;
} }
@ -246,7 +246,7 @@ public class MessageHandlerTest extends ActiveMQTestBase {
private final CountDownLatch latch; private final CountDownLatch latch;
public MyHandler(final CountDownLatch latch) { MyHandler(final CountDownLatch latch) {
this.latch = latch; this.latch = latch;
} }
@ -326,7 +326,7 @@ public class MessageHandlerTest extends ActiveMQTestBase {
private final CountDownLatch latch; private final CountDownLatch latch;
public MyHandler(final CountDownLatch latch) { MyHandler(final CountDownLatch latch) {
this.latch = latch; this.latch = latch;
} }

View File

@ -72,7 +72,7 @@ public class MultipleThreadFilterOneTest extends ActiveMQTestBase {
public final AtomicInteger errors = new AtomicInteger(0); public final AtomicInteger errors = new AtomicInteger(0);
public SomeProducer() throws Exception { SomeProducer() throws Exception {
locator = createNonHALocator(isNetty); locator = createNonHALocator(isNetty);
factory = locator.createSessionFactory(); factory = locator.createSessionFactory();
prodSession = factory.createSession(false, false); prodSession = factory.createSession(false, false);
@ -135,7 +135,7 @@ public class MultipleThreadFilterOneTest extends ActiveMQTestBase {
final AtomicInteger errors = new AtomicInteger(0); final AtomicInteger errors = new AtomicInteger(0);
public SomeConsumer(int nr) throws Exception { SomeConsumer(int nr) throws Exception {
locator = createNonHALocator(isNetty); locator = createNonHALocator(isNetty);
factory = locator.createSessionFactory(); factory = locator.createSessionFactory();
consumerSession = factory.createSession(false, false); consumerSession = factory.createSession(false, false);

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