Start working on trying to get the javadoc stuff to pass without the lint stuff.

"mvn install" now works without the lint, but a "mvn install javadoc:jar" still fails.   Since that is what the release plugin uses, need to keep the lint there for now.  Still lots of failures.
This commit is contained in:
Daniel Kulp 2015-06-09 15:29:58 -04:00
parent e608f24bfb
commit 419a3cc213
34 changed files with 78 additions and 74 deletions

View File

@ -26,7 +26,7 @@ import org.jboss.logmanager.ExtLogRecord;
/** /**
* This class contains a tool where programs could intercept for LogMessage given an interval of time between {@link #startCapture()} * This class contains a tool where programs could intercept for LogMessage given an interval of time between {@link #startCapture()}
* and {@link #stopCapture()} * and {@link #stopCapture()}
* <p/> *
* Be careful with this use as this is intended for testing only (such as testcases) * Be careful with this use as this is intended for testing only (such as testcases)
*/ */
public class AssertionLoggerHandler extends ExtHandler public class AssertionLoggerHandler extends ExtHandler

View File

@ -35,7 +35,6 @@ import java.util.concurrent.TimeUnit;
* JGroups channels. * JGroups channels.
* *
* @see JGroupsBroadcastEndpoint * @see JGroupsBroadcastEndpoint
* @see UDPBroadcastEndpoint
*/ */
public interface BroadcastEndpoint public interface BroadcastEndpoint
{ {

View File

@ -240,7 +240,7 @@ public abstract class JGroupsBroadcastEndpoint implements BroadcastEndpoint
/** /**
* This class maintain a global Map of JChannels wrapped in JChannelWrapper for * This class maintain a global Map of JChannels wrapped in JChannelWrapper for
* the purpose of reference counting. * the purpose of reference counting.
* <p/> *
* Wherever a JChannel is needed it should only get it by calling the getChannel() * Wherever a JChannel is needed it should only get it by calling the getChannel()
* method of this class. The real disconnect of channels are also done here only. * method of this class. The real disconnect of channels are also done here only.
*/ */

View File

@ -21,7 +21,7 @@ import org.apache.activemq.artemis.spi.core.protocol.RemotingConnection;
/** /**
* A member of the topology. * A member of the topology.
* <p> *
* Each TopologyMember represents a single server and possibly any backup server that may take over * Each TopologyMember represents a single server and possibly any backup server that may take over
* its duties (using the nodeId of the original server). * its duties (using the nodeId of the original server).
*/ */
@ -42,10 +42,10 @@ public interface TopologyMember
/** /**
* Returns the {@code scale-down-group-name} of the live server with this Topology entry. * Returns the {@code scale-down-group-name} of the live server with this Topology entry.
* <p/> * <p>
* This is a server configuration value. a live server will only send its messages to another live server * This is a server configuration value. a live server will only send its messages to another live server
* with matching {@code scale-down-group-name}. * with matching {@code scale-down-group-name}.
* <p/> * <p>
* *
* @return the {@code scale-down-group-name} * @return the {@code scale-down-group-name}
*/ */

View File

@ -20,8 +20,6 @@ import java.util.Map;
/** /**
* An AcceptorControl is used to manage Acceptors. * An AcceptorControl is used to manage Acceptors.
*
* @see Acceptor
*/ */
public interface AcceptorControl extends ActiveMQComponentControl public interface AcceptorControl extends ActiveMQComponentControl
{ {
@ -33,8 +31,6 @@ public interface AcceptorControl extends ActiveMQComponentControl
/** /**
* Returns the class name of the AcceptorFactory implementation * Returns the class name of the AcceptorFactory implementation
* used by this acceptor. * used by this acceptor.
*
* @see AcceptorFactory
*/ */
String getFactoryClassName(); String getFactoryClassName();

View File

@ -25,7 +25,7 @@ package org.apache.activemq.artemis.api.core.management;
* <li>Core messages to a notification address (default value is {@code activemq.notifications}) * <li>Core messages to a notification address (default value is {@code activemq.notifications})
* <li>JMS messages * <li>JMS messages
* </ul> * </ul>
* @see the ActiveMQ Artemis user manual section on "Management Notifications" * see the ActiveMQ Artemis user manual section on "Management Notifications"
*/ */
public interface NotificationType public interface NotificationType
{ {

View File

@ -150,8 +150,6 @@ public final class ObjectNameBuilder
/** /**
* Returns the ObjectName used by DiscoveryGroupControl. * Returns the ObjectName used by DiscoveryGroupControl.
*
* @see DiscoveryGroupControl
*/ */
public ObjectName getDiscoveryGroupObjectName(final String name) throws Exception public ObjectName getDiscoveryGroupObjectName(final String name) throws Exception
{ {
@ -160,7 +158,6 @@ public final class ObjectNameBuilder
/** /**
* Returns the ObjectName used by JMSServerControl. * Returns the ObjectName used by JMSServerControl.
* @see org.apache.activemq.artemis.api.jms.management.JMSServerControl
*/ */
public ObjectName getJMSServerObjectName() throws Exception public ObjectName getJMSServerObjectName() throws Exception
{ {
@ -169,7 +166,6 @@ public final class ObjectNameBuilder
/** /**
* Returns the ObjectName used by JMSQueueControl. * Returns the ObjectName used by JMSQueueControl.
* @see org.apache.activemq.artemis.api.jms.management.JMSQueueControl
*/ */
public ObjectName getJMSQueueObjectName(final String name) throws Exception public ObjectName getJMSQueueObjectName(final String name) throws Exception
{ {
@ -178,8 +174,6 @@ public final class ObjectNameBuilder
/** /**
* Returns the ObjectName used by TopicControl. * Returns the ObjectName used by TopicControl.
*
* @see TopicControl
*/ */
public ObjectName getJMSTopicObjectName(final String name) throws Exception public ObjectName getJMSTopicObjectName(final String name) throws Exception
{ {
@ -188,7 +182,6 @@ public final class ObjectNameBuilder
/** /**
* Returns the ObjectName used by ConnectionFactoryControl. * Returns the ObjectName used by ConnectionFactoryControl.
* @see org.apache.activemq.artemis.api.jms.management.ConnectionFactoryControl
*/ */
public ObjectName getConnectionFactoryObjectName(final String name) throws Exception public ObjectName getConnectionFactoryObjectName(final String name) throws Exception
{ {

View File

@ -374,7 +374,6 @@ public interface QueueControl
* it will flush one cycle on internal executors, so you would be sure that any pending tasks are done before you call * it will flush one cycle on internal executors, so you would be sure that any pending tasks are done before you call
* any other measure. * any other measure.
* It is useful if you need the exact number of counts on a message * It is useful if you need the exact number of counts on a message
* @throws Exception
*/ */
void flushExecutor(); void flushExecutor();

View File

@ -1857,7 +1857,7 @@ public final class ClientSessionImpl implements ClientSessionInternal, FailureLi
* If you ever tried to debug XIDs you will know what this is about. * If you ever tried to debug XIDs you will know what this is about.
* This will serialize and deserialize the XID to the same way it's going to be printed on server logs * This will serialize and deserialize the XID to the same way it's going to be printed on server logs
* or print-data. * or print-data.
* <p/> * <p>
* This will convert to the same XID deserialized on the Server, hence we will be able to debug eventual stuff * This will convert to the same XID deserialized on the Server, hence we will be able to debug eventual stuff
* *
* @param xid * @param xid

View File

@ -39,12 +39,12 @@ import org.apache.activemq.artemis.utils.TypedProperties;
/** /**
* This class is used to search for members on the cluster through the opaque interface {@link BroadcastEndpoint}. * This class is used to search for members on the cluster through the opaque interface {@link BroadcastEndpoint}.
* <p/> *
* There are two current implementations, and that's probably all we will ever need. * There are two current implementations, and that's probably all we will ever need.
* <p/> *
* We will probably keep both interfaces for a while as UDP is a simple solution requiring no extra dependencies which * We will probably keep both interfaces for a while as UDP is a simple solution requiring no extra dependencies which
* is suitable for users looking for embedded solutions. * is suitable for users looking for embedded solutions.
* <p/> *
*/ */
public final class DiscoveryGroup implements ActiveMQComponent public final class DiscoveryGroup implements ActiveMQComponent
{ {

View File

@ -62,13 +62,13 @@ import org.apache.activemq.artemis.utils.VersionLoader;
/** /**
* This class will return specific packets for different types of actions happening on a messaging protocol. * This class will return specific packets for different types of actions happening on a messaging protocol.
* <p/> *
* This is trying to unify the Core client into multiple protocols. * This is trying to unify the Core client into multiple protocols.
* <p/> *
* Returning null in certain packets means no action is taken on this specific protocol. * Returning null in certain packets means no action is taken on this specific protocol.
* <p/> *
* Semantic properties could also be added to this implementation. * Semantic properties could also be added to this implementation.
* <p/> *
* Implementations of this class need to be stateless. * Implementations of this class need to be stateless.
*/ */

View File

@ -21,8 +21,7 @@ import org.apache.activemq.artemis.core.protocol.core.impl.PacketImpl;
/** /**
* Ping is sent on the client side by {@link org.apache.activemq.artemis.core.client.impl.ClientSessionFactoryImpl}. At the server's * Ping is sent on the client side by {@link org.apache.activemq.artemis.core.client.impl.ClientSessionFactoryImpl}. At the server's
* side it is handled by {@link org.apache.activemq.artemis.core.remoting.server.impl.RemotingServiceImpl} * side it is handled by org.apache.activemq.artemis.core.remoting.server.impl.RemotingServiceImpl
* @see org.apache.activemq.artemis.spi.core.protocol.RemotingConnection#checkDataReceived()
*/ */
public final class Ping extends PacketImpl public final class Ping extends PacketImpl
{ {

View File

@ -27,7 +27,7 @@ public interface NotificationService
* </ul> * </ul>
* in addition to the properties defined in <code>props</code> * in addition to the properties defined in <code>props</code>
* *
* @see ManagementHelper * @see org.apache.activemq.artemis.api.core.management.ManagementHelper
*/ */
void sendNotification(Notification notification) throws Exception; void sendNotification(Notification notification) throws Exception;

View File

@ -25,7 +25,7 @@ import org.apache.activemq.artemis.api.core.TransportConfigurationHelper;
/** /**
* A ConnectorFactory is used by the client for creating connectors. * A ConnectorFactory is used by the client for creating connectors.
* <p> * <p>
* A Connector is used to connect to an {@link org.apache.activemq.artemis.spi.core.remoting.Acceptor}. * A Connector is used to connect to an org.apache.activemq.artemis.spi.core.remoting.Acceptor.
*/ */
public interface ConnectorFactory extends TransportConfigurationHelper public interface ConnectorFactory extends TransportConfigurationHelper
{ {

View File

@ -173,7 +173,7 @@ public abstract class SessionContext
/** /**
* If we are doing a simple rollback on the RA, we need to ack the last message sent to the consumer, * If we are doing a simple rollback on the RA, we need to ack the last message sent to the consumer,
* otherwise DLQ won't work. * otherwise DLQ won't work.
* <p/> * <p>
* this is because we only ACK after on the RA, We may review this if we always acked earlier. * this is because we only ACK after on the RA, We may review this if we always acked earlier.
* *
* @param lastMessageAsDelivered * @param lastMessageAsDelivered

View File

@ -58,8 +58,8 @@ public class ActiveMQJMSClient
* updated whenever the cluster topology changes. If the topology includes backup servers that * updated whenever the cluster topology changes. If the topology includes backup servers that
* information is also propagated to the client so that it can know which server to failover onto * information is also propagated to the client so that it can know which server to failover onto
* in case of live server failure. * in case of live server failure.
* @param discoveryAddress The UDP group address to listen for updates * @param groupConfiguration
* @param discoveryPort the UDP port to listen for updates * @param jmsFactoryType
* @return the ActiveMQConnectionFactory * @return the ActiveMQConnectionFactory
*/ */
public static ActiveMQConnectionFactory createConnectionFactoryWithHA(final DiscoveryGroupConfiguration groupConfiguration, JMSFactoryType jmsFactoryType) public static ActiveMQConnectionFactory createConnectionFactoryWithHA(final DiscoveryGroupConfiguration groupConfiguration, JMSFactoryType jmsFactoryType)
@ -98,8 +98,8 @@ public class ActiveMQJMSClient
* *
* The UDP address and port are used to listen for live servers in the cluster * The UDP address and port are used to listen for live servers in the cluster
* *
* @param discoveryAddress The UDP group address to listen for updates * @param groupConfiguration
* @param discoveryPort the UDP port to listen for updates * @param jmsFactoryType
* @return the ActiveMQConnectionFactory * @return the ActiveMQConnectionFactory
*/ */
public static ActiveMQConnectionFactory createConnectionFactoryWithoutHA(final DiscoveryGroupConfiguration groupConfiguration, JMSFactoryType jmsFactoryType) public static ActiveMQConnectionFactory createConnectionFactoryWithoutHA(final DiscoveryGroupConfiguration groupConfiguration, JMSFactoryType jmsFactoryType)
@ -142,6 +142,7 @@ public class ActiveMQJMSClient
* downloaded and automatically updated whenever the cluster topology changes. If the topology * downloaded and automatically updated whenever the cluster topology changes. If the topology
* includes backup servers that information is also propagated to the client so that it can know * includes backup servers that information is also propagated to the client so that it can know
* which server to failover onto in case of live server failure. * which server to failover onto in case of live server failure.
* @param jmsFactoryType
* @param initialServers The initial set of servers used to make a connection to the cluster. * @param initialServers The initial set of servers used to make a connection to the cluster.
* Each one is tried in turn until a successful connection is made. Once a connection * Each one is tried in turn until a successful connection is made. Once a connection
* is made, the cluster topology is downloaded and the rest of the list is ignored. * is made, the cluster topology is downloaded and the rest of the list is ignored.
@ -184,6 +185,7 @@ public class ActiveMQJMSClient
* <p> * <p>
* The ActiveMQConnectionFactory is not updated automatically as the cluster topology changes, and * The ActiveMQConnectionFactory is not updated automatically as the cluster topology changes, and
* no HA backup information is propagated to the client * no HA backup information is propagated to the client
* @param jmsFactoryType
* @param transportConfigurations * @param transportConfigurations
* @return the ActiveMQConnectionFactory * @return the ActiveMQConnectionFactory
*/ */

View File

@ -284,7 +284,6 @@ public interface JMSQueueControl extends DestinationControl
* it will flush one cycle on internal executors, so you would be sure that any pending tasks are done before you call * it will flush one cycle on internal executors, so you would be sure that any pending tasks are done before you call
* any other measure. * any other measure.
* It is useful if you need the exact number of counts on a message * It is useful if you need the exact number of counts on a message
* @throws Exception
*/ */
void flushExecutor(); void flushExecutor();
@ -305,7 +304,7 @@ public interface JMSQueueControl extends DestinationControl
/** /**
* Lists all the messages being deliver per consumer. * Lists all the messages being deliver per consumer.
* <br> * <br>
* The Map's key is a toString representation for the consumer. Each consumer will then return a Map<String,Object>[] same way is returned by {@link #listScheduledMessages()} * The Map's key is a toString representation for the consumer. Each consumer will then return a {@code Map<String,Object>[]} same way is returned by {@link #listScheduledMessages()}
*/ */
@Operation(desc = "List all messages being delivered per consumer") @Operation(desc = "List all messages being delivered per consumer")
Map<String, Map<String, Object>[]> listDeliveringMessages() throws Exception; Map<String, Map<String, Object>[]> listDeliveringMessages() throws Exception;

View File

@ -23,7 +23,7 @@ import java.security.PrivilegedAction;
/** /**
* <p>This class will provide default properties for constructors</p> * <p>This class will provide default properties for constructors</p>
* *
* <table border='1'> * <table border='1' summary=''>
* <tr> <td>Name</td> <td>Default Value</td></tr> * <tr> <td>Name</td> <td>Default Value</td></tr>
* <tr> <td>AMQ_HOST or org.apache.activemq.AMQ_HOST</td> <td>localhost</td></tr> * <tr> <td>AMQ_HOST or org.apache.activemq.AMQ_HOST</td> <td>localhost</td></tr>
* <tr><td>AMQ_PORT or org.apache.activemq.AMQ_PORT</td> <td>61616</td></tr> * <tr><td>AMQ_PORT or org.apache.activemq.AMQ_PORT</td> <td>61616</td></tr>

View File

@ -40,11 +40,13 @@ import javax.naming.spi.NamingManager;
import org.apache.activemq.artemis.core.client.ActiveMQClientLogger; import org.apache.activemq.artemis.core.client.ActiveMQClientLogger;
/** /**
* A read-only Context <p/> This version assumes it and all its subcontext are * A read-only Context
* <p>
* This version assumes it and all its subcontext are
* read-only and any attempt to modify (e.g. through bind) will result in an * read-only and any attempt to modify (e.g. through bind) will result in an
* OperationNotSupportedException. Each Context in the tree builds a cache of * OperationNotSupportedException. Each Context in the tree builds a cache of
* the entries in all sub-contexts to optimise the performance of lookup. * the entries in all sub-contexts to optimise the performance of lookup.
* </p> * <p>
* <p> * <p>
* This implementation is intended to optimise the performance of lookup(String) * This implementation is intended to optimise the performance of lookup(String)
* to about the level of a HashMap get. It has been observed that the scheme * to about the level of a HashMap get. It has been observed that the scheme

View File

@ -204,7 +204,6 @@ public class FileJMSConfiguration extends JMSConfigurationImpl implements Deploy
* @param queues * @param queues
* @param topics * @param topics
* @param domain * @param domain
* @return
*/ */
protected void newConfig(final ArrayList<JMSQueueConfiguration> queues, protected void newConfig(final ArrayList<JMSQueueConfiguration> queues,
final ArrayList<TopicConfiguration> topics, String domain) final ArrayList<TopicConfiguration> topics, String domain)

View File

@ -28,7 +28,6 @@ import org.apache.activemq.artemis.core.server.ActiveMQComponent;
* <p> * <p>
* Notice also that even on the callback methods it's possible to pass the sync mode. That will only * Notice also that even on the callback methods it's possible to pass the sync mode. That will only
* make sense on the NIO operations. * make sense on the NIO operations.
* @see org.apache.activemq.artemis.utils.IDGenerator
*/ */
public interface Journal extends ActiveMQComponent public interface Journal extends ActiveMQComponent
{ {
@ -206,7 +205,7 @@ public interface Journal extends ActiveMQComponent
/** /**
* This method will start compact using the compactorExecutor and block up to timeout seconds * This method will start compact using the compactorExecutor and block up to timeout seconds
* @param timeout the timeout in seconds or block forever if <= 0 * @param timeout the timeout in seconds or block forever if {@code <= 0}
* @throws Exception * @throws Exception
*/ */
void scheduleCompactAndBlock(int timeout) throws Exception; void scheduleCompactAndBlock(int timeout) throws Exception;

View File

@ -45,7 +45,7 @@ import org.apache.activemq.artemis.core.journal.impl.dataformat.JournalInternalR
/** /**
* Journal used at a replicating backup server during the synchronization of data with the 'live' * Journal used at a replicating backup server during the synchronization of data with the 'live'
* server. It just wraps a single {@link JournalFile}. * server. It just wraps a single {@link JournalFile}.
* <p/> *
* Its main purpose is to store the data as a Journal would, but without verifying records. * Its main purpose is to store the data as a Journal would, but without verifying records.
*/ */
public final class FileWrapperJournal extends JournalBase public final class FileWrapperJournal extends JournalBase

View File

@ -53,7 +53,7 @@ public interface JournalFile
boolean isCanReclaim(); boolean isCanReclaim();
/** This is a field to identify that records on this file actually belong to the current file. /** This is a field to identify that records on this file actually belong to the current file.
* The possible implementation for this is fileID & Integer.MAX_VALUE */ * The possible implementation for this is fileID &amp; Integer.MAX_VALUE */
int getRecordID(); int getRecordID();
long getFileID(); long getFileID();

View File

@ -193,7 +193,7 @@ public class JournalFilesRepository
/** /**
* Set the {link #nextFileID} value to {@code targetUpdate} if the current value is less than * Set the {link #nextFileID} value to {@code targetUpdate} if the current value is less than
* {@code targetUpdate}. * {@code targetUpdate}.
* <p/> *
* Notice that {@code nextFileID} is incremented before being used, see * Notice that {@code nextFileID} is incremented before being used, see
* {@link JournalFilesRepository#generateFileID()}. * {@link JournalFilesRepository#generateFileID()}.
* *
@ -542,7 +542,7 @@ public class JournalFilesRepository
* *
* @return uninitialized JournalFile * @return uninitialized JournalFile
* @throws Exception * @throws Exception
* @see {@link JournalImpl#initFileHeader(SequentialFileFactory, SequentialFile, int, long)} * @see JournalImpl#initFileHeader(SequentialFileFactory, SequentialFile, int, long)
*/ */
public JournalFile takeFile(final boolean keepOpened, public JournalFile takeFile(final boolean keepOpened,
final boolean multiAIO, final boolean multiAIO,
@ -580,7 +580,7 @@ public class JournalFilesRepository
/** /**
* Creates files for journal synchronization of a replicated backup. * Creates files for journal synchronization of a replicated backup.
* <p/> *
* In order to simplify synchronization, the file IDs in the backup match those in the live * In order to simplify synchronization, the file IDs in the backup match those in the live
* server. * server.
* *

View File

@ -72,8 +72,8 @@ import org.apache.activemq.artemis.utils.ConcurrentHashSet;
import org.apache.activemq.artemis.utils.DataConstants; import org.apache.activemq.artemis.utils.DataConstants;
/** /**
* <p>A circular log implementation.</p * <p>A circular log implementation.</p>
* <p/> * <p></p>
* <p>Look at {@link JournalImpl#load(LoaderCallback)} for the file layout * <p>Look at {@link JournalImpl#load(LoaderCallback)} for the file layout
*/ */
public class JournalImpl extends JournalBase implements TestableJournal, JournalRecordProvider public class JournalImpl extends JournalBase implements TestableJournal, JournalRecordProvider
@ -202,7 +202,7 @@ public class JournalImpl extends JournalBase implements TestableJournal, Journal
* We don't lock the journal during the whole compacting operation. During compacting we only * We don't lock the journal during the whole compacting operation. During compacting we only
* lock it (i) when gathering the initial structure, and (ii) when replicating the structures * lock it (i) when gathering the initial structure, and (ii) when replicating the structures
* after finished compacting. * after finished compacting.
* <p/> *
* However we need to lock it while taking and updating snapshots * However we need to lock it while taking and updating snapshots
*/ */
private final ReadWriteLock journalLock = new ReentrantReadWriteLock(); private final ReadWriteLock journalLock = new ReentrantReadWriteLock();
@ -1100,9 +1100,9 @@ public class JournalImpl extends JournalBase implements TestableJournal, Journal
/** /**
* <p>If the system crashed after a prepare was called, it should store information that is required to bring the transaction * <p>If the system crashed after a prepare was called, it should store information that is required to bring the transaction
* back to a state it could be committed. </p> * back to a state it could be committed. </p>
* <p/> * <p></p>
* <p> transactionData allows you to store any other supporting user-data related to the transaction</p> * <p> transactionData allows you to store any other supporting user-data related to the transaction</p>
* <p/> * <p></p>
* <p> This method also uses the same logic applied on {@link JournalImpl#appendCommitRecord(long, boolean)} * <p> This method also uses the same logic applied on {@link JournalImpl#appendCommitRecord(long, boolean)}
* *
* @param txID * @param txID
@ -1448,7 +1448,7 @@ public class JournalImpl extends JournalBase implements TestableJournal, Journal
/** /**
* Note: This method can't be called from the main executor, as it will invoke other methods * Note: This method can't be called from the main executor, as it will invoke other methods
* depending on it. * depending on it.
* <p/> *
* Note: only synchronized methods on journal are methods responsible for the life-cycle such as * Note: only synchronized methods on journal are methods responsible for the life-cycle such as
* stop, start records will still come as this is being executed * stop, start records will still come as this is being executed
*/ */
@ -1656,9 +1656,9 @@ public class JournalImpl extends JournalBase implements TestableJournal, Journal
/** /**
* <p>Load data accordingly to the record layouts</p> * <p>Load data accordingly to the record layouts</p>
* <p/> * <p></p>
* <p>Basic record layout:</p> * <p>Basic record layout:</p>
* <table border=1> * <table border=1 summary="">
* <tr><td><b>Field Name</b></td><td><b>Size</b></td></tr> * <tr><td><b>Field Name</b></td><td><b>Size</b></td></tr>
* <tr><td>RecordType</td><td>Byte (1)</td></tr> * <tr><td>RecordType</td><td>Byte (1)</td></tr>
* <tr><td>FileID</td><td>Integer (4 bytes)</td></tr> * <tr><td>FileID</td><td>Integer (4 bytes)</td></tr>
@ -1666,15 +1666,15 @@ public class JournalImpl extends JournalBase implements TestableJournal, Journal
* <tr><td>TransactionID <i>(if record is transactional)</i></td><td>Long (8 bytes)</td></tr> * <tr><td>TransactionID <i>(if record is transactional)</i></td><td>Long (8 bytes)</td></tr>
* <tr><td>RecordID</td><td>Long (8 bytes)</td></tr> * <tr><td>RecordID</td><td>Long (8 bytes)</td></tr>
* <tr><td>BodySize(Add, update and delete)</td><td>Integer (4 bytes)</td></tr> * <tr><td>BodySize(Add, update and delete)</td><td>Integer (4 bytes)</td></tr>
* <tr><td>UserDefinedRecordType (If add/update only)</td><td>Byte (1)</td</tr> * <tr><td>UserDefinedRecordType (If add/update only)</td><td>Byte (1)</td></tr>
* <tr><td>RecordBody</td><td>Byte Array (size=BodySize)</td></tr> * <tr><td>RecordBody</td><td>Byte Array (size=BodySize)</td></tr>
* <tr><td>Check Size</td><td>Integer (4 bytes)</td></tr> * <tr><td>Check Size</td><td>Integer (4 bytes)</td></tr>
* </table> * </table>
* <p/> * <p></p>
* <p> The check-size is used to validate if the record is valid and complete </p> * <p> The check-size is used to validate if the record is valid and complete </p>
* <p/> * <p></p>
* <p>Commit/Prepare record layout:</p> * <p>Commit/Prepare record layout:</p>
* <table border=1> * <table border=1 summary="">
* <tr><td><b>Field Name</b></td><td><b>Size</b></td></tr> * <tr><td><b>Field Name</b></td><td><b>Size</b></td></tr>
* <tr><td>RecordType</td><td>Byte (1)</td></tr> * <tr><td>RecordType</td><td>Byte (1)</td></tr>
* <tr><td>FileID</td><td>Integer (4 bytes)</td></tr> * <tr><td>FileID</td><td>Integer (4 bytes)</td></tr>
@ -1685,9 +1685,9 @@ public class JournalImpl extends JournalBase implements TestableJournal, Journal
* <tr><td>ExtraDataBytes</td><td>Bytes (sized by ExtraDataLength)</td></tr> * <tr><td>ExtraDataBytes</td><td>Bytes (sized by ExtraDataLength)</td></tr>
* <tr><td>* FileID(n)</td><td>Integer (4 bytes)</td></tr> * <tr><td>* FileID(n)</td><td>Integer (4 bytes)</td></tr>
* <tr><td>* NumberOfElements(n)</td><td>Integer (4 bytes)</td></tr> * <tr><td>* NumberOfElements(n)</td><td>Integer (4 bytes)</td></tr>
* <tr><td>CheckSize</td><td>Integer (4 bytes)</td</tr> * <tr><td>CheckSize</td><td>Integer (4 bytes)</td></tr>
* </table> * </table>
* <p/> * <p></p>
* <p> * FileID and NumberOfElements are the transaction summary, and they will be repeated (N)umberOfFiles times </p> * <p> * FileID and NumberOfElements are the transaction summary, and they will be repeated (N)umberOfFiles times </p>
*/ */
public JournalLoadInformation load(final LoaderCallback loadManager) throws Exception public JournalLoadInformation load(final LoaderCallback loadManager) throws Exception
@ -3074,7 +3074,7 @@ public class JournalImpl extends JournalBase implements TestableJournal, Journal
/** /**
* Returns Map with a {@link JournalFile} for all existing files. * Returns Map with a {@link JournalFile} for all existing files.
* <p/> *
* These are the files needed to be sent to a backup in order to synchronize it. * These are the files needed to be sent to a backup in order to synchronize it.
* *
* @param fileIds * @param fileIds

View File

@ -21,7 +21,7 @@ import org.apache.activemq.artemis.journal.ActiveMQJournalLogger;
/** /**
* *
* <p>The journal consists of an ordered list of journal files Fn where 0 <= n <= N</p> * <p>The journal consists of an ordered list of journal files Fn where {@code 0 <= n <= N}</p>
* *
* <p>A journal file can contain either positives (pos) or negatives (neg)</p> * <p>A journal file can contain either positives (pos) or negatives (neg)</p>
* *
@ -29,9 +29,9 @@ import org.apache.activemq.artemis.journal.ActiveMQJournalLogger;
* *
* <p>A file Fn can be deleted if, and only if the following criteria are satisified</p> * <p>A file Fn can be deleted if, and only if the following criteria are satisified</p>
* *
* <p>1) All pos in a file Fn, must have corresponding neg in any file Fm where m >= n.</p> * <p>1) All pos in a file Fn, must have corresponding neg in any file Fm where {@code m >= n}.</p>
* *
* <p>2) All pos that correspond to any neg in file Fn, must all live in any file Fm where 0 <= m <= n * <p>2) All pos that correspond to any neg in file Fn, must all live in any file Fm where {@code 0 <= m <= n}
* which are also marked for deletion in the same pass of the algorithm.</p> * which are also marked for deletion in the same pass of the algorithm.</p>
*/ */
public class Reclaimer public class Reclaimer

View File

@ -348,7 +348,7 @@ public abstract class ComparisonExpression extends BinaryExpression implements B
} }
/** /**
* Only Numeric expressions can be used in >, >=, < or <= expressions.s * Only Numeric expressions can be used in {@code >}, {@code >=}, {@code <} or {@code <=} expressions.
* *
* @param expr * @param expr
*/ */
@ -372,7 +372,7 @@ public abstract class ComparisonExpression extends BinaryExpression implements B
} }
/** /**
* Validates that the expression can be used in == or <> expression. Cannot * Validates that the expression can be used in {@code ==} or {@code <>} expression. Cannot
* not be NULL TRUE or FALSE litterals. * not be NULL TRUE or FALSE litterals.
* *
* @param expr * @param expr

View File

@ -37,7 +37,7 @@ import org.apache.activemq.artemis.utils.ConfigurationHelper;
/** /**
* ConnectorsService will pool some resource for updates, e.g. Twitter, then the changes are picked * ConnectorsService will pool some resource for updates, e.g. Twitter, then the changes are picked
* and converted into a ServerMessage for a given destination (queue). * and converted into a ServerMessage for a given destination (queue).
* <p/> * <p>
* It may also listen to a queue, and forward them (e.g. messages arriving at the queue are picked * It may also listen to a queue, and forward them (e.g. messages arriving at the queue are picked
* and tweeted to some Twitter account). * and tweeted to some Twitter account).
*/ */

View File

@ -506,7 +506,7 @@ public class ServerConsumerImpl implements ServerConsumer, ReadyListener
/** /**
* Prompt delivery and send a "forced delivery" message to the consumer. * Prompt delivery and send a "forced delivery" message to the consumer.
* <p/> * <p>
* When the consumer receives such a "forced delivery" message, it discards it and knows that * When the consumer receives such a "forced delivery" message, it discards it and knows that
* there are no other messages to be delivered. * there are no other messages to be delivered.
*/ */

View File

@ -55,7 +55,7 @@ public interface Acceptor extends ActiveMQComponent
/** /**
* Whether this acceptor allows insecure connections. * Whether this acceptor allows insecure connections.
* @throws java.lang.IllegalStatException if false @setDefaultActiveMQPrincipal * @throws java.lang.IllegalStateException if false @setDefaultActiveMQPrincipal
*/ */
boolean isUnsecurable(); boolean isUnsecurable();
} }

View File

@ -25,7 +25,7 @@ import org.apache.activemq.artemis.spi.core.protocol.ProtocolManager;
/** /**
* A factory for creating acceptors. * A factory for creating acceptors.
* <p/> * <p>
* An Acceptor is an endpoint that a {@link org.apache.activemq.artemis.spi.core.remoting.Connector} will connect to and is used by the remoting service. * An Acceptor is an endpoint that a {@link org.apache.activemq.artemis.spi.core.remoting.Connector} will connect to and is used by the remoting service.
*/ */
public interface AcceptorFactory public interface AcceptorFactory

View File

@ -22,8 +22,9 @@ public interface ServerConnectionLifeCycleListener extends ConnectionLifeCycleLi
* This method is used both by client connector creation and server connection creation through acceptors. * This method is used both by client connector creation and server connection creation through acceptors.
* the acceptor will be set to null on client operations * the acceptor will be set to null on client operations
* *
* @param The acceptor here will be always null on a client connection created event. * @param acceptor The acceptor here will be always null on a client connection created event.
* @param connection the connection that has been created * @param connection the connection that has been created
* @param protocol the protocol to use
*/ */
void connectionCreated(Acceptor acceptor, Connection connection, String protocol); void connectionCreated(Acceptor acceptor, Connection connection, String protocol);
} }

View File

@ -58,6 +58,21 @@
<artifactId>artemis-selector</artifactId> <artifactId>artemis-selector</artifactId>
<version>${project.version}</version> <version>${project.version}</version>
</dependency> </dependency>
<!-- stuff needed to resolve various classes during javadoc processing -->
<dependency>
<groupId>org.jboss.logging</groupId>
<artifactId>jboss-logging-processor</artifactId>
<scope>provided</scope>
<optional>true</optional>
</dependency>
<dependency>
<groupId>xalan</groupId>
<artifactId>xalan</artifactId>
<version>2.7.2</version>
<optional>true</optional>
<scope>provided</scope>
</dependency>
</dependencies> </dependencies>
<properties> <properties>

View File

@ -859,6 +859,7 @@
<groupId>org.apache.maven.plugins</groupId> <groupId>org.apache.maven.plugins</groupId>
<artifactId>maven-javadoc-plugin</artifactId> <artifactId>maven-javadoc-plugin</artifactId>
<configuration> <configuration>
<!--additionalparam>-Xmaxwarns 1</additionalparam-->
<additionalparam>-Xdoclint:none</additionalparam> <additionalparam>-Xdoclint:none</additionalparam>
</configuration> </configuration>
</plugin> </plugin>