Fixing javadoc and removing the -Xdoclint option from the pom.xml
Also, since JDK 1.8 is no longer required I'm downgrading the JDK to 1.7 minimal. We can review that back to 1.8 when we really need 1.8 features.
This commit is contained in:
parent
fd93a7c268
commit
309ce4324c
|
@ -140,7 +140,7 @@ public final class XmlDataImporter implements Action
|
|||
* This is the normal constructor for programmatic access to the
|
||||
* <code>org.apache.activemq.artemis.core.persistence.impl.journal.XmlDataImporter</code> if the session passed
|
||||
* in uses auto-commit for sends.
|
||||
* <p/>
|
||||
* <br>
|
||||
* If the session needs to be transactional then use the constructor which takes 2 sessions.
|
||||
*
|
||||
* @param inputStream the stream from which to read the XML for import
|
||||
|
@ -154,7 +154,7 @@ public final class XmlDataImporter implements Action
|
|||
|
||||
/**
|
||||
* This is the constructor to use if you wish to import all messages transactionally.
|
||||
* <p/>
|
||||
* <br>
|
||||
* Pass in a session which doesn't use auto-commit for sends, and one that does (for management
|
||||
* operations necessary during import).
|
||||
*
|
||||
|
|
|
@ -119,10 +119,10 @@ public final class UUID
|
|||
* identity hash (ie. same contents generate same hash) manually, without
|
||||
* sacrificing speed too much. Although multiplications with modulos would
|
||||
* generate better hashing, let's use just shifts, and do 2 bytes at a time.
|
||||
* <p/>
|
||||
* <br>
|
||||
* Of course, assuming UUIDs are randomized enough, even simpler approach
|
||||
* might be good enough?
|
||||
* <p/>
|
||||
* <br>
|
||||
* Is this a good hash? ... one of these days I better read more about basic
|
||||
* hashing techniques I swear!
|
||||
*/
|
||||
|
|
|
@ -628,10 +628,10 @@ public final class ClientConsumerImpl implements ClientConsumerInternal
|
|||
* Such messages come from message senders who are configured to compress large messages, and
|
||||
* if some of the messages are compressed below the min-large-message-size limit, they are sent
|
||||
* as regular messages.
|
||||
* <p/>
|
||||
* <br>
|
||||
* However when decompressing the message, we are not sure how large the message could be..
|
||||
* for that reason we fake a large message controller that will deal with the message as it was a large message
|
||||
* <p/>
|
||||
* <br>
|
||||
* Say that you sent a 1G message full of spaces. That could be just bellow 100K compressed but you wouldn't have
|
||||
* enough memory to decompress it
|
||||
*/
|
||||
|
|
|
@ -31,7 +31,7 @@ public class SessionSendContinuationMessage extends SessionContinuationMessage
|
|||
private MessageInternal message;
|
||||
/**
|
||||
* In case, we are using a different handler than the one set on the {@link org.apache.activemq.artemis.api.core.client.ClientSession}
|
||||
* <p/>
|
||||
* <br>
|
||||
* This field is only used at the client side.
|
||||
*
|
||||
* @see org.apache.activemq.artemis.api.core.client.ClientSession#setSendAcknowledgementHandler(SendAcknowledgementHandler)
|
||||
|
|
|
@ -29,7 +29,7 @@ public class SessionSendMessage extends MessagePacket
|
|||
|
||||
/**
|
||||
* In case, we are using a different handler than the one set on the {@link org.apache.activemq.artemis.api.core.client.ClientSession}
|
||||
* <p/>
|
||||
* <br>
|
||||
* This field is only used at the client side.
|
||||
*
|
||||
* @see org.apache.activemq.artemis.api.core.client.ClientSession#setSendAcknowledgementHandler(SendAcknowledgementHandler)
|
||||
|
|
|
@ -52,7 +52,7 @@ public final class OrderedExecutorFactory implements ExecutorFactory
|
|||
|
||||
/**
|
||||
* An executor that always runs all tasks in order, using a delegate executor to run the tasks.
|
||||
* <p/>
|
||||
* <br>
|
||||
* More specifically, any call B to the {@link #execute(Runnable)} method that happens-after another call A to the
|
||||
* same method, will result in B's task running after A's.
|
||||
*/
|
||||
|
|
|
@ -54,7 +54,7 @@ public class AsynchronousFileImpl implements AsynchronousFile
|
|||
|
||||
/**
|
||||
* This definition needs to match Version.h on the native sources.
|
||||
* <p/>
|
||||
* <br>
|
||||
* Or else the native module won't be loaded because of version mismatches
|
||||
*/
|
||||
private static final int EXPECTED_NATIVE_VERSION = 52;
|
||||
|
@ -72,7 +72,7 @@ public class AsynchronousFileImpl implements AsynchronousFile
|
|||
|
||||
/**
|
||||
* AIO can't guarantee ordering over callbacks.
|
||||
* <p/>
|
||||
* <br>
|
||||
* We use this {@link PriorityQueue} to hold values until they are in order
|
||||
*/
|
||||
private final PriorityQueue<CallbackHolder> pendingCallbacks = new PriorityQueue<CallbackHolder>();
|
||||
|
@ -699,7 +699,7 @@ public class AsynchronousFileImpl implements AsynchronousFile
|
|||
|
||||
/**
|
||||
* Explicitly adding a compare to clause that returns 0 for at least the same object.
|
||||
* <p/>
|
||||
* <br>
|
||||
* If {@link Comparable#compareTo(Object)} does not return 0 -for at least the same object- some
|
||||
* Collection classes methods will fail (example {@link PriorityQueue#remove(Object)}. If it
|
||||
* returns 0, then {@link #equals(Object)} must return {@code true} for the exact same cases,
|
||||
|
|
|
@ -45,7 +45,7 @@ public class JournalFilesRepository
|
|||
|
||||
/**
|
||||
* Used to debug the consistency of the journal ordering.
|
||||
* <p/>
|
||||
* <br>
|
||||
* This is meant to be false as these extra checks would cause performance issues
|
||||
*/
|
||||
private static final boolean CHECK_CONSISTENCE = false;
|
||||
|
|
|
@ -2576,12 +2576,12 @@ public class JournalImpl extends JournalBase implements TestableJournal, Journal
|
|||
// -----------------------------------------------------------------------------
|
||||
|
||||
/**
|
||||
* <p/>
|
||||
* <br>
|
||||
* Checks for holes on the transaction (a commit written but with an incomplete transaction).
|
||||
* <p/>
|
||||
* <br>
|
||||
* This method will validate if the transaction (PREPARE/COMMIT) is complete as stated on the
|
||||
* COMMIT-RECORD.
|
||||
* <p/>
|
||||
* <br>
|
||||
* For details see {@link JournalCompleteRecordTX} about how the transaction-summary is recorded.
|
||||
*
|
||||
* @param journalTransaction
|
||||
|
|
|
@ -201,7 +201,6 @@ public interface AMQSubscription extends AMQSubscriptionRecovery
|
|||
/**
|
||||
* Informs the Broker if the subscription needs to intervention to recover it's state
|
||||
* e.g. DurableTopicSubscriber may do
|
||||
* @see org.apache.activemq.broker.region.cursors.PendingMessageCursor
|
||||
* @return true if recovery required
|
||||
*/
|
||||
boolean isRecoveryRequired();
|
||||
|
|
|
@ -22,9 +22,6 @@ import org.apache.activemq.command.ConnectionInfo;
|
|||
import org.apache.activemq.state.ConnectionState;
|
||||
import org.apache.activemq.artemis.core.protocol.openwire.OpenWireConnection;
|
||||
|
||||
/**
|
||||
* @See org.apache.activemq.broker.TransportConnectionState
|
||||
*/
|
||||
public class AMQTransportConnectionState extends ConnectionState
|
||||
{
|
||||
|
||||
|
|
|
@ -39,7 +39,6 @@ public interface AMQPConnectionContext
|
|||
* This is for future use and should be kept returning false.
|
||||
*
|
||||
* We will have to do some testing before we make this return true
|
||||
* @return
|
||||
*/
|
||||
boolean isSyncOnFlush();
|
||||
|
||||
|
@ -48,9 +47,6 @@ public interface AMQPConnectionContext
|
|||
/**
|
||||
* This is for the Remoting layer to push bytes on the AMQP Connection
|
||||
* The buffer readerIndex should be at the latest read byte after this method is called
|
||||
*
|
||||
* @param buffer
|
||||
* @return
|
||||
*/
|
||||
void inputBuffer(ByteBuf buffer);
|
||||
|
||||
|
|
|
@ -34,9 +34,6 @@ import org.proton.plug.handler.impl.DefaultEventHandler;
|
|||
import org.proton.plug.util.ByteUtil;
|
||||
import org.proton.plug.util.DebugInfo;
|
||||
|
||||
/**
|
||||
* Clebert Suconic
|
||||
*/
|
||||
public abstract class AbstractConnectionContext extends ProtonInitializable implements AMQPConnectionContext
|
||||
{
|
||||
|
||||
|
@ -79,8 +76,6 @@ public abstract class AbstractConnectionContext extends ProtonInitializable impl
|
|||
|
||||
/**
|
||||
* See comment at {@link org.proton.plug.AMQPConnectionContext#isSyncOnFlush()}
|
||||
* @return
|
||||
* @See {@link org.proton.plug.AMQPConnectionContext#isSyncOnFlush()}
|
||||
*/
|
||||
public boolean isSyncOnFlush()
|
||||
{
|
||||
|
|
|
@ -25,10 +25,10 @@ import org.jboss.logging.Messages;
|
|||
|
||||
/**
|
||||
* Logger Code 11
|
||||
* <p/>
|
||||
* <p>
|
||||
* Each message id must be 6 digits long starting with 10, the 3rd digit should be 9. So the range
|
||||
* is from 219000 to 119999.
|
||||
* <p/>
|
||||
* <p>
|
||||
* Once released, methods should not be deleted as they may be referenced by knowledge base
|
||||
* articles. Unused methods should be marked as deprecated.
|
||||
*/
|
||||
|
|
|
@ -22,15 +22,10 @@ import java.util.concurrent.locks.AbstractQueuedSynchronizer;
|
|||
/**
|
||||
* <p>This class will use the framework provided to by AbstractQueuedSynchronizer.</p>
|
||||
* <p>AbstractQueuedSynchronizer is the framework for any sort of concurrent synchronization, such as Semaphores, events, etc, based on AtomicIntegers.</p>
|
||||
* <p/>
|
||||
* <p>This class works just like CountDownLatch, with the difference you can also increase the counter</p>
|
||||
* <p/>
|
||||
* <p>It could be used for sync points when one process is feeding the latch while another will wait when everything is done. (e.g. waiting IO completions to finish)</p>
|
||||
* <p/>
|
||||
* <p>On ActiveMQ Artemis we have the requirement of increment and decrement a counter until the user fires a ready handler (commit). At that point we just act as a regular countDown.</p>
|
||||
* <p/>
|
||||
* <p>Note: This latch is reusable. Once it reaches zero, you can call up again, and reuse it on further waits.</p>
|
||||
* <p/>
|
||||
* <p>For example: prepareTransaction will wait for the current completions, and further adds will be called on the latch. Later on when commit is called you can reuse the same latch.</p>
|
||||
*/
|
||||
public class ReusableLatch
|
||||
|
|
|
@ -26,10 +26,10 @@ import org.jboss.logging.annotations.MessageLogger;
|
|||
|
||||
/**
|
||||
* Logger Code 15
|
||||
* <p/>
|
||||
* <br>
|
||||
* each message id must be 6 digits long starting with 15, the 3rd digit donates
|
||||
* the level so
|
||||
* <p/>
|
||||
* <br>
|
||||
* <pre>
|
||||
* INF0 1
|
||||
* WARN 2
|
||||
|
@ -38,7 +38,7 @@ import org.jboss.logging.annotations.MessageLogger;
|
|||
* TRACE 5
|
||||
* FATAL 6
|
||||
* </pre>
|
||||
* <p/>
|
||||
* <br>
|
||||
* so an INFO message would be 151000 to 151999
|
||||
*/
|
||||
@MessageLogger(projectCode = "AMQ")
|
||||
|
|
|
@ -23,7 +23,7 @@ import javax.jms.Topic;
|
|||
|
||||
|
||||
/**
|
||||
* The MCF default properties - these are set in the <tx-connection-factory> at the jms-ds.xml
|
||||
* The MCF default properties - these are set in the tx-connection-factory at the jms-ds.xml
|
||||
*/
|
||||
public class ActiveMQRAMCFProperties extends ConnectionFactoryProperties implements Serializable
|
||||
{
|
||||
|
|
|
@ -294,7 +294,7 @@ public final class ActiveMQRAManagedConnectionFactory implements ManagedConnecti
|
|||
|
||||
/**
|
||||
* Set the resource adapter
|
||||
* <p/>
|
||||
* <br>
|
||||
* This should ensure that when the RA is stopped, this MCF will be stopped as well.
|
||||
*
|
||||
* @param ra The resource adapter
|
||||
|
|
|
@ -1243,9 +1243,6 @@ public final class ActiveMQRASession implements QueueSession, TopicSession, XAQu
|
|||
|
||||
/**
|
||||
* Get the XA resource
|
||||
*
|
||||
* @return The XA resource
|
||||
* @throws IllegalStateException If non XA connection
|
||||
*/
|
||||
public XAResource getXAResource()
|
||||
{
|
||||
|
@ -1889,10 +1886,6 @@ public final class ActiveMQRASession implements QueueSession, TopicSession, XAQu
|
|||
return (TopicSession) s;
|
||||
}
|
||||
|
||||
/**
|
||||
* @throws SystemException
|
||||
* @throws RollbackException
|
||||
*/
|
||||
public void checkState() throws JMSException
|
||||
{
|
||||
if (mc != null)
|
||||
|
|
|
@ -1808,7 +1808,6 @@ public class ActiveMQResourceAdapter implements ResourceAdapter, Serializable
|
|||
}
|
||||
|
||||
/**
|
||||
* @return
|
||||
* @see ActiveMQRAProperties#getJgroupsChannelLocatorClass()
|
||||
*/
|
||||
public String getJgroupsChannelLocatorClass()
|
||||
|
@ -1817,8 +1816,7 @@ public class ActiveMQResourceAdapter implements ResourceAdapter, Serializable
|
|||
}
|
||||
|
||||
/**
|
||||
* @return
|
||||
* @see ActiveMQRAProperties#setJgroupsChannelLocatorClass()
|
||||
* @see ActiveMQRAProperties#setJgroupsChannelLocatorClass(String)
|
||||
*/
|
||||
public void setJgroupsChannelLocatorClass(String jgroupsChannelLocatorClass)
|
||||
{
|
||||
|
@ -1835,8 +1833,7 @@ public class ActiveMQResourceAdapter implements ResourceAdapter, Serializable
|
|||
}
|
||||
|
||||
/**
|
||||
* @return
|
||||
* @see ActiveMQRAProperties#setJgroupsChannelRefName()
|
||||
* @see ActiveMQRAProperties#setJgroupsChannelRefName(java.lang.String)
|
||||
*/
|
||||
public void setJgroupsChannelRefName(String jgroupsChannelRefName)
|
||||
{
|
||||
|
|
|
@ -23,9 +23,9 @@ import org.jboss.logging.Messages;
|
|||
|
||||
/**
|
||||
* Logger Code 23
|
||||
* <p/>
|
||||
* <br>
|
||||
* each message id must be 6 digits long starting with 10, the 3rd digit should be 9
|
||||
* <p/>
|
||||
* <br>
|
||||
* so 239000 to 239999
|
||||
*/
|
||||
@MessageBundle(projectCode = "AMQ")
|
||||
|
|
13
pom.xml
13
pom.xml
|
@ -98,7 +98,7 @@
|
|||
<skipLicenseCheck>true</skipLicenseCheck>
|
||||
<skipStyleCheck>true</skipStyleCheck>
|
||||
<geronimo.jms.2.spec.version>1.0-alpha-1</geronimo.jms.2.spec.version>
|
||||
|
||||
|
||||
<javac-compiler-id>javac-with-errorprone</javac-compiler-id>
|
||||
</properties>
|
||||
|
||||
|
@ -451,12 +451,12 @@
|
|||
<activation>
|
||||
<property>
|
||||
<name>m2e.version</name>
|
||||
</property>
|
||||
</property>
|
||||
</activation>
|
||||
<properties>
|
||||
<javac-compiler-id>javac</javac-compiler-id>
|
||||
</properties>
|
||||
</profile>
|
||||
</profile>
|
||||
<profile>
|
||||
<id>dev</id>
|
||||
<modules>
|
||||
|
@ -848,7 +848,7 @@
|
|||
<configuration>
|
||||
<rules>
|
||||
<requireJavaVersion>
|
||||
<version>1.8.0</version>
|
||||
<version>1.7.0</version>
|
||||
</requireJavaVersion>
|
||||
</rules>
|
||||
</configuration>
|
||||
|
@ -858,10 +858,6 @@
|
|||
<plugin>
|
||||
<groupId>org.apache.maven.plugins</groupId>
|
||||
<artifactId>maven-javadoc-plugin</artifactId>
|
||||
<configuration>
|
||||
<!--additionalparam>-Xmaxwarns 1</additionalparam-->
|
||||
<additionalparam>-Xdoclint:none</additionalparam>
|
||||
</configuration>
|
||||
</plugin>
|
||||
<plugin>
|
||||
<groupId>org.apache.maven.plugins</groupId>
|
||||
|
@ -1021,7 +1017,6 @@
|
|||
<aggregate>true</aggregate>
|
||||
<excludePackageNames>com.restfully.*:org.jboss.resteasy.examples.*:org.jboss.resteasy.tests.*
|
||||
</excludePackageNames>
|
||||
<additionalparam>-Xdoclint:none</additionalparam>
|
||||
</configuration>
|
||||
</plugin>
|
||||
<plugin>
|
||||
|
|
|
@ -41,13 +41,13 @@ import org.junit.Test;
|
|||
|
||||
/**
|
||||
* Test the loss of messages detected during testing with ActiveMQ 5.4.1 and 5.4.2.
|
||||
* <p/>
|
||||
* <br>
|
||||
* Symptoms: - 1 record is lost "early" in the stream. - no more records lost.
|
||||
* <p/>
|
||||
* <br>
|
||||
* Test Configuration: - Broker Settings: - Destination Policy - Occurs with "Destination Policy" using Store Cursor and
|
||||
* a memory limit - Not reproduced without "Destination Policy" defined - Persistence Adapter - Memory: Does not occur.
|
||||
* - KahaDB: Occurs. - Messages - Occurs with TextMessage and BinaryMessage - Persistent messages.
|
||||
* <p/>
|
||||
* <br>
|
||||
* Notes: - Lower memory limits increase the rate of occurrence. - Higher memory limits may prevent the problem
|
||||
* (probably because memory limits not reached). - Producers sending a number of messages before consumers come online
|
||||
* increases rate of occurrence.
|
||||
|
@ -75,7 +75,7 @@ public class AMQ3167Test {
|
|||
/**
|
||||
* Create a new, unsecured, client connection to the test broker using the given username and password. This
|
||||
* connection bypasses all security.
|
||||
* <p/>
|
||||
* <br>
|
||||
* Don't forget to start the connection or no messages will be received by consumers even though producers will work
|
||||
* fine.
|
||||
*
|
||||
|
|
|
@ -49,7 +49,7 @@ import static org.junit.Assert.fail;
|
|||
/**
|
||||
* Testing how the broker reacts when a SQL Exception is thrown from
|
||||
* org.apache.activemq.store.jdbc.TransactionContext.executeBatch().
|
||||
* <p/>
|
||||
* <br>
|
||||
* see https://issues.apache.org/jira/browse/AMQ-4636
|
||||
*/
|
||||
public class AMQ4636Test {
|
||||
|
@ -123,7 +123,7 @@ public class AMQ4636Test {
|
|||
/**
|
||||
* adding a TestTransactionContext (wrapper to TransactionContext) so an SQLException is triggered
|
||||
* during TransactionContext.executeBatch() when called in the broker.
|
||||
* <p/>
|
||||
* <br>
|
||||
* Expectation: SQLException triggers a connection shutdown and failover should kick and try to redeliver the
|
||||
* message. SQLException should NOT be returned to client
|
||||
*/
|
||||
|
|
|
@ -71,27 +71,27 @@ import static org.junit.Assert.*;
|
|||
/**
|
||||
* Test creates a broker network with two brokers - producerBroker (with a
|
||||
* message producer attached) and consumerBroker (with consumer attached)
|
||||
* <p/>
|
||||
* <br>
|
||||
* Simulates network duplicate message by stopping and restarting the
|
||||
* consumerBroker after message (with message ID ending in 120) is persisted to
|
||||
* consumerBrokerstore BUT BEFORE ack sent to the producerBroker over the
|
||||
* network connection. When the network connection is reestablished the
|
||||
* producerBroker resends message (with messageID ending in 120).
|
||||
* <p/>
|
||||
* <br>
|
||||
* Expectation:
|
||||
* <p/>
|
||||
* <br>
|
||||
* With the following policy entries set, would expect the duplicate message to
|
||||
* be read from the store and dispatched to the consumer - where the duplicate
|
||||
* could be detected by consumer.
|
||||
* <p/>
|
||||
* <br>
|
||||
* PolicyEntry policy = new PolicyEntry(); policy.setQueue(">");
|
||||
* policy.setEnableAudit(false); policy.setUseCache(false);
|
||||
* policy.setExpireMessagesPeriod(0);
|
||||
* <p/>
|
||||
* <p/>
|
||||
* <br>
|
||||
* <br>
|
||||
* Note 1: Network needs to use replaywhenNoConsumers so enabling the
|
||||
* networkAudit to avoid this scenario is not feasible.
|
||||
* <p/>
|
||||
* <br>
|
||||
* NOTE 2: Added a custom plugin to the consumerBroker so that the
|
||||
* consumerBroker shutdown will occur after a message has been persisted to
|
||||
* consumerBroker store but before an ACK is sent back to ProducerBroker. This
|
||||
|
|
|
@ -54,7 +54,7 @@ import static org.junit.Assert.assertEquals;
|
|||
|
||||
/**
|
||||
* Stuck messages test client.
|
||||
* <p/>
|
||||
* <br>
|
||||
* Will kick of publisher and consumer simultaneously, and will usually result in stuck messages on the queue.
|
||||
*/
|
||||
@RunWith(Parameterized.class)
|
||||
|
|
|
@ -32,7 +32,7 @@ import org.slf4j.LoggerFactory;
|
|||
|
||||
/*
|
||||
* simulate message flow which cause the following exception in the broker
|
||||
* (exception logged by client) <p/> 2007-07-24 13:51:23,624
|
||||
* (exception logged by client) <br> 2007-07-24 13:51:23,624
|
||||
* com.easynet.halo.Halo ERROR (LoggingErrorHandler.java: 23) JMS failure
|
||||
* javax.jms.JMSException: Transaction 'TX:ID:dmt-53625-1185281414694-1:0:344'
|
||||
* has not been started. at
|
||||
|
|
|
@ -33,7 +33,7 @@ import org.slf4j.LoggerFactory;
|
|||
* The configuration is set to except a maximum of 2 concurrent connections
|
||||
* As the exception is deliberately ignored, the ActiveMQConnection would continue to
|
||||
* attempt to connect unless the connection's transport was also stopped on an error.
|
||||
* <p/>
|
||||
* <br>
|
||||
* As the maximum connections allowed is 2, no more connections would be allowed unless
|
||||
* the transport was adequately destroyed on the broker side.
|
||||
*/
|
||||
|
|
|
@ -57,7 +57,7 @@ import org.junit.Test;
|
|||
* to be compliant with JDBC spec; officially commit is not supposed to be
|
||||
* called on a connection that uses autocommit.The oracle v12 driver does a
|
||||
* check for autocommitSpecCompliance and it causes issues
|
||||
* <p/>
|
||||
* <br>
|
||||
* To test; wrap the datasource used by the broker and check for autocommit
|
||||
* before delegating to real datasource. If commit is called on connection with
|
||||
* autocommit, wrapper throws a SQLException.
|
||||
|
|
|
@ -41,18 +41,18 @@ import org.junit.Assert;
|
|||
* This test demonstrates and verifies the behaviour of a network bridge when it
|
||||
* forwards a message to a queue that is full and producer flow control is
|
||||
* enabled.
|
||||
* <p/>
|
||||
* <br>
|
||||
* The expected behaviour is that the bridge will stop forwarding messages to
|
||||
* the full queue once the associated demand consumer's prefetch is full, but
|
||||
* will continue to forward messages to the other queues that are not full.
|
||||
* <p/>
|
||||
* <br>
|
||||
* In actuality, a message that is sent <b>asynchronously</b> to a local queue,
|
||||
* but blocked by producer flow control on the remote queue, will stop the
|
||||
* bridge from forwarding all subsequent messages, even those destined for
|
||||
* remote queues that are not full. In the same scenario, but with a message
|
||||
* that is sent <b>synchronously</b> to the local queue, the bridge continues
|
||||
* forwarding messages to remote queues that are not full.
|
||||
* <p/>
|
||||
* <br>
|
||||
* This test demonstrates the differing behaviour via the following scenario:
|
||||
* <ul>
|
||||
* <li>broker0, designated as the local broker, produces messages to two shared
|
||||
|
@ -73,7 +73,7 @@ import org.junit.Assert;
|
|||
* control on the "slow consumer" queue should not affect the "fast consumer"
|
||||
* queue, the expectation is that the fast consumer in broker1 will finish
|
||||
* processing all its messages well ahead of the slow consumer.
|
||||
* <p/>
|
||||
* <br>
|
||||
* The difference between expected and actual behaviour is demonstrated by
|
||||
* changing the messages produced by broker0 from persistent to non-persistent.
|
||||
* With persistent messages, broker0 dispatches synchronously and the expected
|
||||
|
@ -81,14 +81,14 @@ import org.junit.Assert;
|
|||
* the slow consumer). With non-persistent messages, broker0 dispatches
|
||||
* asynchronously and the expected behaviour is <b>not</b> observed (i.e., the
|
||||
* fast consumer is only marginally faster than the slow consumer).
|
||||
* <p/>
|
||||
* <br>
|
||||
* Since the expected behaviour may be desirable for both persistent and
|
||||
* non-persistent messages, this test also demonstrates an enhancement to the
|
||||
* network bridge configuration: <tt>isAlwaysSendSync</tt>. When false the
|
||||
* bridge operates as originally observed. When <tt>true</tt>, the bridge
|
||||
* operates with the same behaviour as was originally observed with persistent
|
||||
* messages, for both persistent and non-persistent messages.
|
||||
* <p/>
|
||||
* <br>
|
||||
* https://issues.apache.org/jira/browse/AMQ-3331
|
||||
*
|
||||
* @author schow
|
||||
|
|
|
@ -29,7 +29,7 @@ import org.junit.Test;
|
|||
|
||||
/**
|
||||
* A JMSBridgeClusteredTest
|
||||
* <p/>
|
||||
* <br>
|
||||
* Tests of jms bridge using HA connection factories.
|
||||
*/
|
||||
public class JMSBridgeClusteredTest extends ClusteredBridgeTestBase
|
||||
|
|
|
@ -5,9 +5,9 @@
|
|||
* The ASF licenses this file to You under the Apache License, Version 2.0
|
||||
* (the "License"); you may not use this file except in compliance with
|
||||
* the License. You may obtain a copy of the License at
|
||||
* <p/>
|
||||
* <br>
|
||||
* http://www.apache.org/licenses/LICENSE-2.0
|
||||
* <p/>
|
||||
* <br>
|
||||
* Unless required by applicable law or agreed to in writing, software
|
||||
* distributed under the License is distributed on an "AS IS" BASIS,
|
||||
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
|
||||
|
|
|
@ -5,9 +5,9 @@
|
|||
* The ASF licenses this file to You under the Apache License, Version 2.0
|
||||
* (the "License"); you may not use this file except in compliance with
|
||||
* the License. You may obtain a copy of the License at
|
||||
* <p/>
|
||||
* <br>
|
||||
* http://www.apache.org/licenses/LICENSE-2.0
|
||||
* <p/>
|
||||
* <br>
|
||||
* Unless required by applicable law or agreed to in writing, software
|
||||
* distributed under the License is distributed on an "AS IS" BASIS,
|
||||
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
|
||||
|
|
|
@ -46,18 +46,18 @@ import java.util.concurrent.atomic.AtomicInteger;
|
|||
* -- https://issues.jboss.org/browse/HORNETQ-746
|
||||
* Stress test using netty with NIO and many JMS clients concurrently, to try
|
||||
* and induce a deadlock.
|
||||
* <p/>
|
||||
* <br>
|
||||
* A large number of JMS clients are started concurrently. Some produce to queue
|
||||
* 1 over one connection, others consume from queue 1 and produce to queue 2
|
||||
* over a second connection, and others consume from queue 2 over a third
|
||||
* connection.
|
||||
* <p/>
|
||||
* <br>
|
||||
* Each operation is done in a JMS transaction, sending/consuming one message
|
||||
* per transaction.
|
||||
* <p/>
|
||||
* <br>
|
||||
* The server is set up with netty, with only one NIO worker and 1 activemq
|
||||
* server worker. This increases the chance for the deadlock to occur.
|
||||
* <p/>
|
||||
* <br>
|
||||
* If the deadlock occurs, all threads will block/die. A simple transaction
|
||||
* counting strategy is used to verify that the count has reached the expected
|
||||
* value.
|
||||
|
|
|
@ -39,7 +39,7 @@ import org.junit.Test;
|
|||
|
||||
/**
|
||||
* A LargeMessageCompressTest
|
||||
* <p/>
|
||||
* <br>
|
||||
* Just extend the LargeMessageTest
|
||||
*/
|
||||
public class LargeMessageCompressTest extends LargeMessageTest
|
||||
|
|
|
@ -34,7 +34,7 @@ import org.junit.Test;
|
|||
|
||||
/**
|
||||
* A PagingOrderTest.
|
||||
* <p/>
|
||||
* <br>
|
||||
* PagingTest has a lot of tests already. I decided to create a newer one more specialized on Ordering and counters
|
||||
*/
|
||||
public class PagingSyncTest extends ActiveMQTestBase
|
||||
|
|
|
@ -2819,7 +2819,7 @@ public class PagingTest extends ActiveMQTestBase
|
|||
* - Consume the entire destination (not in page mode any more)
|
||||
* - Add stuff to a transaction again
|
||||
* - Check order
|
||||
* <p/>
|
||||
* <br>
|
||||
* Test under discussion at : http://community.jboss.org/thread/154061?tstart=0
|
||||
*/
|
||||
@Test
|
||||
|
|
|
@ -1715,7 +1715,7 @@ public abstract class ClusterTestBase extends ActiveMQTestBase
|
|||
/**
|
||||
* Server lacks a {@link ClusterConnectionConfiguration} necessary for the remote (replicating)
|
||||
* backup case.
|
||||
* <p/>
|
||||
* <br>
|
||||
* Use
|
||||
* {@link #setupClusterConnectionWithBackups(String, String, boolean, int, boolean, int, int[])}
|
||||
* to add it.
|
||||
|
|
|
@ -44,7 +44,7 @@ import org.junit.Test;
|
|||
|
||||
/**
|
||||
* A MultiThreadFailoverTest
|
||||
* <p/>
|
||||
* <br>
|
||||
* Test Failover where failure is prompted by another thread
|
||||
*/
|
||||
public class AsynchronousFailoverTest extends FailoverTestBase
|
||||
|
|
|
@ -39,7 +39,7 @@ import java.util.HashMap;
|
|||
|
||||
/**
|
||||
* A PagingFailoverTest
|
||||
* <p/>
|
||||
* <br>
|
||||
* TODO: validate replication failover also
|
||||
*/
|
||||
public class PagingFailoverTest extends FailoverTestBase
|
||||
|
|
|
@ -20,7 +20,7 @@ import org.apache.activemq.artemis.core.config.Configuration;
|
|||
|
||||
/**
|
||||
* A RemoteServerConfiguration.
|
||||
* <p/>
|
||||
* <br>
|
||||
* These classes are initialized through their class name through {@link Class#newInstance()}.
|
||||
* Therefore they must have a no argument constructor, and if they are inner classes they must be
|
||||
* static.
|
||||
|
|
|
@ -46,20 +46,20 @@ import org.junit.Test;
|
|||
|
||||
/**
|
||||
* This will test Discovery test on JGroups and UDP.
|
||||
* <p/>
|
||||
* <br>
|
||||
* In some configurations IPV6 may be a challenge. To make sure this test works, you may add this
|
||||
* property to your JVM settings: {@literal -Djgroups.bind_addr=::1}
|
||||
* <p/>
|
||||
* <br>
|
||||
* Or ultimately you may also turn off IPV6: {@literal -Djava.net.preferIPv4Stack=true}
|
||||
* <p/>
|
||||
* <br>
|
||||
* Note when you are not sure about your IP settings of your test machine, you should make sure
|
||||
* that the jgroups.bind_addr and java.net.preferXXStack by defining them explicitly, for example
|
||||
* if you would like to use IPV6, set BOTH properties to your JVM like the following:
|
||||
* -Djgroups.bind_addr=::1 -Djava.net.preferIPv6Addresses=true
|
||||
* <p/>
|
||||
* <br>
|
||||
* or if you prefer IPV4:
|
||||
* -Djgroups.bind_addr=localhost -Djava.net.preferIPv4Stack=true
|
||||
* <p/>
|
||||
* <br>
|
||||
* Also: Make sure you add integration-tests/src/tests/resources to your project path on the
|
||||
* tests/integration-tests
|
||||
*/
|
||||
|
|
|
@ -63,7 +63,7 @@ import java.util.Map;
|
|||
|
||||
/**
|
||||
* A JMSFailoverTest
|
||||
* <p/>
|
||||
* <br>
|
||||
* A simple test to test setFailoverListener when using the JMS API.
|
||||
*/
|
||||
public class JMSFailoverListenerTest extends ActiveMQTestBase
|
||||
|
|
|
@ -70,7 +70,7 @@ import java.util.concurrent.atomic.AtomicBoolean;
|
|||
|
||||
/**
|
||||
* A JMSFailoverTest
|
||||
* <p/>
|
||||
* <br>
|
||||
* A simple test to test failover when using the JMS API.
|
||||
* Most of the failover tests are done on the Core API.
|
||||
*/
|
||||
|
|
|
@ -67,7 +67,7 @@ import java.util.Set;
|
|||
|
||||
/**
|
||||
* A QueueControlTest
|
||||
* <p/>
|
||||
* <br>
|
||||
* on this testContaining WithRealData will use real data on the journals
|
||||
*/
|
||||
public class JMSQueueControlTest extends ManagementTestBase
|
||||
|
|
|
@ -33,7 +33,7 @@ public class SimpleStartStopTest extends ActiveMQTestBase
|
|||
/**
|
||||
* Start / stopping the server shouldn't generate any errors.
|
||||
* Also it shouldn't bloat the journal with lots of IDs (it should do some cleanup when possible)
|
||||
* <p/>
|
||||
* <br>
|
||||
* This is also validating that the same server could be restarted after stopped
|
||||
*
|
||||
* @throws Exception
|
||||
|
|
|
@ -20,7 +20,7 @@ import java.util.StringTokenizer;
|
|||
|
||||
/**
|
||||
* 1.1 frames
|
||||
* <p/>
|
||||
* <br>
|
||||
* 1. CONNECT/STOMP(new)
|
||||
* 2. CONNECTED
|
||||
* 3. SEND
|
||||
|
|
|
@ -27,7 +27,7 @@ import org.apache.activemq.artemis.utils.TimeAndCounterIDGenerator;
|
|||
|
||||
/**
|
||||
* A JournalExample: Just an example on how to use the Journal Directly
|
||||
* <p/>
|
||||
* <br>
|
||||
* TODO: find a better place to store this example
|
||||
*/
|
||||
public class JournalExample
|
||||
|
|
|
@ -116,7 +116,7 @@ public class DurableSubscriptionTest extends JMSTestCase
|
|||
* JMS 1.1 6.11.1: A client can change an existing durable subscription by creating a durable
|
||||
* TopicSubscriber with the same name and a new topic and/or message selector, or NoLocal
|
||||
* attribute. Changing a durable subscription is equivalent to deleting and recreating it.
|
||||
* <p/>
|
||||
* <br>
|
||||
* Test with a different topic (a redeployed topic is a different topic).
|
||||
*/
|
||||
@Test
|
||||
|
@ -169,7 +169,7 @@ public class DurableSubscriptionTest extends JMSTestCase
|
|||
* JMS 1.1 6.11.1: A client can change an existing durable subscription by creating a durable
|
||||
* TopicSubscriber with the same name and a new topic and/or message selector, or NoLocal
|
||||
* attribute. Changing a durable subscription is equivalent to deleting and recreating it.
|
||||
* <p/>
|
||||
* <br>
|
||||
* Test with a different selector.
|
||||
*/
|
||||
@Test
|
||||
|
|
|
@ -29,7 +29,7 @@ import org.junit.Test;
|
|||
|
||||
/**
|
||||
* A MessageWithReadResolveTest
|
||||
* <p/>
|
||||
* <br>
|
||||
* See http://jira.jboss.com/jira/browse/JBMESSAGING-442
|
||||
*/
|
||||
public class MessageWithReadResolveTest extends JMSTestCase
|
||||
|
|
|
@ -39,7 +39,7 @@ import org.junit.Test;
|
|||
|
||||
/**
|
||||
* A ReferenceableTest.
|
||||
* <p/>
|
||||
* <br>
|
||||
* All administered objects should be referenceable and serializable as per spec 4.2
|
||||
*/
|
||||
public class ReferenceableTest extends JMSTestCase
|
||||
|
|
|
@ -27,7 +27,7 @@ import org.junit.Test;
|
|||
|
||||
/**
|
||||
* Test JMS Security.
|
||||
* <p/>
|
||||
* <br>
|
||||
* This test must be run with the Test security config. on the server
|
||||
*/
|
||||
public class SecurityTest extends JMSTestCase
|
||||
|
|
|
@ -43,7 +43,7 @@ public class SelectorTest extends ActiveMQServerTestCase
|
|||
|
||||
/**
|
||||
* Test case for http://jira.jboss.org/jira/browse/JBMESSAGING-105
|
||||
* <p/>
|
||||
* <br>
|
||||
* Two Messages are sent to a queue. There is one receiver on the queue. The receiver only
|
||||
* receives one of the messages due to a message selector only matching one of them. The receiver
|
||||
* is then closed. A new receiver is now attached to the queue. Redelivery of the remaining
|
||||
|
|
|
@ -37,7 +37,7 @@ import java.util.concurrent.CountDownLatch;
|
|||
|
||||
/**
|
||||
* A MultiThreadConsumerStressTest
|
||||
* <p/>
|
||||
* <br>
|
||||
* This test validates consuming / sending messages while compacting is working
|
||||
*/
|
||||
public class MultiThreadConsumerStressTest extends ActiveMQTestBase
|
||||
|
|
|
@ -5,9 +5,9 @@
|
|||
* The ASF licenses this file to You under the Apache License, Version 2.0
|
||||
* (the "License"); you may not use this file except in compliance with
|
||||
* the License. You may obtain a copy of the License at
|
||||
* <p/>
|
||||
* <br>
|
||||
* http://www.apache.org/licenses/LICENSE-2.0
|
||||
* <p/>
|
||||
* <br>
|
||||
* Unless required by applicable law or agreed to in writing, software
|
||||
* distributed under the License is distributed on an "AS IS" BASIS,
|
||||
* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
|
||||
|
|
Loading…
Reference in New Issue