提交 f56e0383 编写于 作者: Y yukon

ROCKETMQ-18 Use apache email as author.

上级 07a8862c
...@@ -31,7 +31,7 @@ It offers a variety of features as follows: ...@@ -31,7 +31,7 @@ It offers a variety of features as follows:
---------- ----------
## RocketMQ Community ## RocketMQ Community
* [`Docker images`](https://registry.hub.docker.com/u/vongosling/rocketmq/) * [`Docker images`](https://registry.hub.docker.com/u/vongosling@apache.org/rocketmq/)
* [RocketMQ Community Projects](https://github.com/rocketmq) * [RocketMQ Community Projects](https://github.com/rocketmq)
---------- ----------
......
...@@ -15,7 +15,4 @@ ...@@ -15,7 +15,4 @@
# See the License for the specific language governing permissions and # See the License for the specific language governing permissions and
# limitations under the License. # limitations under the License.
#
# $Id: consumer.sh 1831 2013-05-16 01:39:51Z shijia.wxr $
#
sh ./runclass.sh org.apache.rocketmq.example.benchmark.Consumer $@ & sh ./runclass.sh org.apache.rocketmq.example.benchmark.Consumer $@ &
...@@ -15,6 +15,6 @@ ...@@ -15,6 +15,6 @@
# limitations under the License. # limitations under the License.
# #
# $Id: producer.sh 1831 2013-05-16 01:39:51Z shijia.wxr $ # $Id: producer.sh 1831 2013-05-16 01:39:51Z vintagewang@apache.org $
# #
sh ./runclass.sh -Dorg.apache.rocketmq.client.sendSmartMsg=true org.apache.rocketmq.example.benchmark.Producer $@ & sh ./runclass.sh -Dorg.apache.rocketmq.client.sendSmartMsg=true org.apache.rocketmq.example.benchmark.Producer $@ &
...@@ -15,7 +15,7 @@ ...@@ -15,7 +15,7 @@
# limitations under the License. # limitations under the License.
# #
# $Id: runserver.sh 1831 2013-05-16 01:39:51Z shijia.wxr $ # $Id: runserver.sh 1831 2013-05-16 01:39:51Z vintagewang@apache.org $
# #
if [ $# -lt 1 ]; if [ $# -lt 1 ];
......
...@@ -15,6 +15,6 @@ ...@@ -15,6 +15,6 @@
# limitations under the License. # limitations under the License.
# #
# $Id: producer.sh 1831 2013-05-16 01:39:51Z shijia.wxr $ # $Id: producer.sh 1831 2013-05-16 01:39:51Z vintagewang@apache.org $
# #
sh ./runclass.sh org.apache.rocketmq.example.benchmark.TransactionProducer $@ sh ./runclass.sh org.apache.rocketmq.example.benchmark.TransactionProducer $@
...@@ -64,7 +64,7 @@ import java.util.concurrent.*; ...@@ -64,7 +64,7 @@ import java.util.concurrent.*;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class BrokerController { public class BrokerController {
private static final Logger log = LoggerFactory.getLogger(LoggerName.BROKER_LOGGER_NAME); private static final Logger log = LoggerFactory.getLogger(LoggerName.BROKER_LOGGER_NAME);
......
...@@ -45,7 +45,7 @@ import java.util.concurrent.atomic.AtomicInteger; ...@@ -45,7 +45,7 @@ import java.util.concurrent.atomic.AtomicInteger;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class BrokerStartup { public class BrokerStartup {
public static Properties properties = null; public static Properties properties = null;
......
...@@ -21,7 +21,7 @@ import io.netty.channel.Channel; ...@@ -21,7 +21,7 @@ import io.netty.channel.Channel;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class ClientChannelInfo { public class ClientChannelInfo {
private final Channel channel; private final Channel channel;
......
...@@ -30,7 +30,7 @@ import java.util.concurrent.TimeUnit; ...@@ -30,7 +30,7 @@ import java.util.concurrent.TimeUnit;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class ClientHousekeepingService implements ChannelEventListener { public class ClientHousekeepingService implements ChannelEventListener {
private static final Logger log = LoggerFactory.getLogger(LoggerName.BROKER_LOGGER_NAME); private static final Logger log = LoggerFactory.getLogger(LoggerName.BROKER_LOGGER_NAME);
......
...@@ -34,7 +34,7 @@ import java.util.concurrent.ConcurrentHashMap; ...@@ -34,7 +34,7 @@ import java.util.concurrent.ConcurrentHashMap;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class ConsumerGroupInfo { public class ConsumerGroupInfo {
private static final Logger log = LoggerFactory.getLogger(LoggerName.BROKER_LOGGER_NAME); private static final Logger log = LoggerFactory.getLogger(LoggerName.BROKER_LOGGER_NAME);
......
...@@ -22,8 +22,8 @@ import java.util.List; ...@@ -22,8 +22,8 @@ import java.util.List;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public interface ConsumerIdsChangeListener { public interface ConsumerIdsChangeListener {
public void consumerIdsChanged(final String group, final List<Channel> channels); void consumerIdsChanged(final String group, final List<Channel> channels);
} }
...@@ -35,7 +35,7 @@ import java.util.concurrent.ConcurrentHashMap; ...@@ -35,7 +35,7 @@ import java.util.concurrent.ConcurrentHashMap;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class ConsumerManager { public class ConsumerManager {
private static final Logger log = LoggerFactory.getLogger(LoggerName.BROKER_LOGGER_NAME); private static final Logger log = LoggerFactory.getLogger(LoggerName.BROKER_LOGGER_NAME);
......
...@@ -23,7 +23,7 @@ import java.util.List; ...@@ -23,7 +23,7 @@ import java.util.List;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class DefaultConsumerIdsChangeListener implements ConsumerIdsChangeListener { public class DefaultConsumerIdsChangeListener implements ConsumerIdsChangeListener {
private final BrokerController brokerController; private final BrokerController brokerController;
......
...@@ -33,7 +33,7 @@ import java.util.concurrent.locks.ReentrantLock; ...@@ -33,7 +33,7 @@ import java.util.concurrent.locks.ReentrantLock;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class ProducerManager { public class ProducerManager {
private static final Logger log = LoggerFactory.getLogger(LoggerName.BROKER_LOGGER_NAME); private static final Logger log = LoggerFactory.getLogger(LoggerName.BROKER_LOGGER_NAME);
......
...@@ -56,7 +56,7 @@ import java.util.concurrent.ConcurrentHashMap; ...@@ -56,7 +56,7 @@ import java.util.concurrent.ConcurrentHashMap;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class Broker2Client { public class Broker2Client {
private static final Logger log = LoggerFactory.getLogger(LoggerName.BROKER_LOGGER_NAME); private static final Logger log = LoggerFactory.getLogger(LoggerName.BROKER_LOGGER_NAME);
......
...@@ -29,7 +29,7 @@ import java.util.concurrent.locks.ReentrantLock; ...@@ -29,7 +29,7 @@ import java.util.concurrent.locks.ReentrantLock;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class RebalanceLockManager { public class RebalanceLockManager {
private static final Logger log = LoggerFactory.getLogger(LoggerName.REBALANCE_LOCK_LOGGER_NAME); private static final Logger log = LoggerFactory.getLogger(LoggerName.REBALANCE_LOCK_LOGGER_NAME);
......
...@@ -30,7 +30,7 @@ import java.util.concurrent.TimeUnit; ...@@ -30,7 +30,7 @@ import java.util.concurrent.TimeUnit;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class BrokerFastFailure { public class BrokerFastFailure {
private static final Logger log = LoggerFactory.getLogger(LoggerName.BROKER_LOGGER_NAME); private static final Logger log = LoggerFactory.getLogger(LoggerName.BROKER_LOGGER_NAME);
......
...@@ -20,7 +20,7 @@ package org.apache.rocketmq.broker.latency; ...@@ -20,7 +20,7 @@ package org.apache.rocketmq.broker.latency;
import java.util.concurrent.*; import java.util.concurrent.*;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class BrokerFixedThreadPoolExecutor extends ThreadPoolExecutor { public class BrokerFixedThreadPoolExecutor extends ThreadPoolExecutor {
public BrokerFixedThreadPoolExecutor(final int corePoolSize, final int maximumPoolSize, final long keepAliveTime, final TimeUnit unit, final BlockingQueue<Runnable> workQueue) { public BrokerFixedThreadPoolExecutor(final int corePoolSize, final int maximumPoolSize, final long keepAliveTime, final TimeUnit unit, final BlockingQueue<Runnable> workQueue) {
......
...@@ -21,7 +21,7 @@ import java.util.concurrent.Callable; ...@@ -21,7 +21,7 @@ import java.util.concurrent.Callable;
import java.util.concurrent.FutureTask; import java.util.concurrent.FutureTask;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class FutureTaskExt<V> extends FutureTask<V> { public class FutureTaskExt<V> extends FutureTask<V> {
private final Runnable runnable; private final Runnable runnable;
......
...@@ -21,7 +21,7 @@ import java.util.List; ...@@ -21,7 +21,7 @@ import java.util.List;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class ManyPullRequest { public class ManyPullRequest {
private final ArrayList<PullRequest> pullRequestList = new ArrayList<PullRequest>(); private final ArrayList<PullRequest> pullRequestList = new ArrayList<PullRequest>();
......
...@@ -22,7 +22,7 @@ import io.netty.channel.Channel; ...@@ -22,7 +22,7 @@ import io.netty.channel.Channel;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class PullRequest { public class PullRequest {
private final RemotingCommand requestCommand; private final RemotingCommand requestCommand;
......
...@@ -31,7 +31,7 @@ import java.util.concurrent.ConcurrentHashMap; ...@@ -31,7 +31,7 @@ import java.util.concurrent.ConcurrentHashMap;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class PullRequestHoldService extends ServiceThread { public class PullRequestHoldService extends ServiceThread {
private static final Logger log = LoggerFactory.getLogger(LoggerName.BROKER_LOGGER_NAME); private static final Logger log = LoggerFactory.getLogger(LoggerName.BROKER_LOGGER_NAME);
......
...@@ -31,7 +31,7 @@ import java.util.concurrent.ConcurrentHashMap; ...@@ -31,7 +31,7 @@ import java.util.concurrent.ConcurrentHashMap;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class ConsumerOffsetManager extends ConfigManager { public class ConsumerOffsetManager extends ConfigManager {
private static final Logger log = LoggerFactory.getLogger(LoggerName.BROKER_LOGGER_NAME); private static final Logger log = LoggerFactory.getLogger(LoggerName.BROKER_LOGGER_NAME);
......
...@@ -42,7 +42,7 @@ import java.util.List; ...@@ -42,7 +42,7 @@ import java.util.List;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
* @author manhong.yqd * @author manhong.yqd
*/ */
public class BrokerOuterAPI { public class BrokerOuterAPI {
......
...@@ -27,7 +27,7 @@ import java.util.List; ...@@ -27,7 +27,7 @@ import java.util.List;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class ManyMessageTransfer extends AbstractReferenceCounted implements FileRegion { public class ManyMessageTransfer extends AbstractReferenceCounted implements FileRegion {
private final ByteBuffer byteBufferHeader; private final ByteBuffer byteBufferHeader;
......
...@@ -26,7 +26,7 @@ import java.nio.channels.WritableByteChannel; ...@@ -26,7 +26,7 @@ import java.nio.channels.WritableByteChannel;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class OneMessageTransfer extends AbstractReferenceCounted implements FileRegion { public class OneMessageTransfer extends AbstractReferenceCounted implements FileRegion {
private final ByteBuffer byteBufferHeader; private final ByteBuffer byteBufferHeader;
......
...@@ -27,7 +27,7 @@ import java.util.List; ...@@ -27,7 +27,7 @@ import java.util.List;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class QueryMessageTransfer extends AbstractReferenceCounted implements FileRegion { public class QueryMessageTransfer extends AbstractReferenceCounted implements FileRegion {
private final ByteBuffer byteBufferHeader; private final ByteBuffer byteBufferHeader;
......
...@@ -54,7 +54,7 @@ import java.util.Random; ...@@ -54,7 +54,7 @@ import java.util.Random;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public abstract class AbstractSendMessageProcessor implements NettyRequestProcessor { public abstract class AbstractSendMessageProcessor implements NettyRequestProcessor {
protected static final Logger log = LoggerFactory.getLogger(LoggerName.BROKER_LOGGER_NAME); protected static final Logger log = LoggerFactory.getLogger(LoggerName.BROKER_LOGGER_NAME);
......
...@@ -62,7 +62,7 @@ import java.util.concurrent.ConcurrentHashMap; ...@@ -62,7 +62,7 @@ import java.util.concurrent.ConcurrentHashMap;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
* @author manhong.yqd * @author manhong.yqd
*/ */
public class AdminBrokerProcessor implements NettyRequestProcessor { public class AdminBrokerProcessor implements NettyRequestProcessor {
......
...@@ -40,7 +40,7 @@ import org.slf4j.LoggerFactory; ...@@ -40,7 +40,7 @@ import org.slf4j.LoggerFactory;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class ClientManageProcessor implements NettyRequestProcessor { public class ClientManageProcessor implements NettyRequestProcessor {
private static final Logger log = LoggerFactory.getLogger(LoggerName.BROKER_LOGGER_NAME); private static final Logger log = LoggerFactory.getLogger(LoggerName.BROKER_LOGGER_NAME);
......
...@@ -34,7 +34,7 @@ import java.util.List; ...@@ -34,7 +34,7 @@ import java.util.List;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class ConsumerManageProcessor implements NettyRequestProcessor { public class ConsumerManageProcessor implements NettyRequestProcessor {
private static final Logger log = LoggerFactory.getLogger(LoggerName.BROKER_LOGGER_NAME); private static final Logger log = LoggerFactory.getLogger(LoggerName.BROKER_LOGGER_NAME);
......
...@@ -39,7 +39,7 @@ import org.slf4j.LoggerFactory; ...@@ -39,7 +39,7 @@ import org.slf4j.LoggerFactory;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class EndTransactionProcessor implements NettyRequestProcessor { public class EndTransactionProcessor implements NettyRequestProcessor {
private static final Logger LOGGER = LoggerFactory.getLogger(LoggerName.TRANSACTION_LOGGER_NAME); private static final Logger LOGGER = LoggerFactory.getLogger(LoggerName.TRANSACTION_LOGGER_NAME);
......
...@@ -26,7 +26,7 @@ import org.slf4j.LoggerFactory; ...@@ -26,7 +26,7 @@ import org.slf4j.LoggerFactory;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class ForwardRequestProcessor implements NettyRequestProcessor { public class ForwardRequestProcessor implements NettyRequestProcessor {
private static final Logger log = LoggerFactory.getLogger(LoggerName.BROKER_LOGGER_NAME); private static final Logger log = LoggerFactory.getLogger(LoggerName.BROKER_LOGGER_NAME);
......
...@@ -58,7 +58,7 @@ import java.util.List; ...@@ -58,7 +58,7 @@ import java.util.List;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class PullMessageProcessor implements NettyRequestProcessor { public class PullMessageProcessor implements NettyRequestProcessor {
private static final Logger LOG = LoggerFactory.getLogger(LoggerName.BROKER_LOGGER_NAME); private static final Logger LOG = LoggerFactory.getLogger(LoggerName.BROKER_LOGGER_NAME);
......
...@@ -40,7 +40,7 @@ import org.slf4j.LoggerFactory; ...@@ -40,7 +40,7 @@ import org.slf4j.LoggerFactory;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class QueryMessageProcessor implements NettyRequestProcessor { public class QueryMessageProcessor implements NettyRequestProcessor {
private static final Logger log = LoggerFactory.getLogger(LoggerName.BROKER_LOGGER_NAME); private static final Logger log = LoggerFactory.getLogger(LoggerName.BROKER_LOGGER_NAME);
......
...@@ -49,7 +49,7 @@ import java.util.List; ...@@ -49,7 +49,7 @@ import java.util.List;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class SendMessageProcessor extends AbstractSendMessageProcessor implements NettyRequestProcessor { public class SendMessageProcessor extends AbstractSendMessageProcessor implements NettyRequestProcessor {
......
...@@ -31,7 +31,7 @@ import java.io.IOException; ...@@ -31,7 +31,7 @@ import java.io.IOException;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
* @author manhong.yqd * @author manhong.yqd
*/ */
public class SlaveSynchronize { public class SlaveSynchronize {
......
...@@ -34,7 +34,7 @@ import java.util.concurrent.ConcurrentHashMap; ...@@ -34,7 +34,7 @@ import java.util.concurrent.ConcurrentHashMap;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class SubscriptionGroupManager extends ConfigManager { public class SubscriptionGroupManager extends ConfigManager {
private static final Logger log = LoggerFactory.getLogger(LoggerName.BROKER_LOGGER_NAME); private static final Logger log = LoggerFactory.getLogger(LoggerName.BROKER_LOGGER_NAME);
......
...@@ -43,7 +43,7 @@ import java.util.concurrent.locks.ReentrantLock; ...@@ -43,7 +43,7 @@ import java.util.concurrent.locks.ReentrantLock;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class TopicConfigManager extends ConfigManager { public class TopicConfigManager extends ConfigManager {
private static final Logger LOG = LoggerFactory.getLogger(LoggerName.BROKER_LOGGER_NAME); private static final Logger LOG = LoggerFactory.getLogger(LoggerName.BROKER_LOGGER_NAME);
......
...@@ -16,7 +16,7 @@ ...@@ -16,7 +16,7 @@
*/ */
/** /**
* $Id: SendMessageTest.java 1831 2013-05-16 01:39:51Z shijia.wxr $ * $Id: SendMessageTest.java 1831 2013-05-16 01:39:51Z vintagewang@apache.org $
*/ */
package org.apache.rocketmq.broker; package org.apache.rocketmq.broker;
......
...@@ -16,7 +16,7 @@ ...@@ -16,7 +16,7 @@
*/ */
/** /**
* $Id: SendMessageTest.java 1831 2013-05-16 01:39:51Z shijia.wxr $ * $Id: SendMessageTest.java 1831 2013-05-16 01:39:51Z vintagewang@apache.org $
*/ */
package org.apache.rocketmq.broker.api; package org.apache.rocketmq.broker.api;
......
...@@ -16,7 +16,7 @@ ...@@ -16,7 +16,7 @@
*/ */
/** /**
* $Id: ConsumerOffsetManagerTest.java 1831 2013-05-16 01:39:51Z shijia.wxr $ * $Id: ConsumerOffsetManagerTest.java 1831 2013-05-16 01:39:51Z vintagewang@apache.org $
*/ */
package org.apache.rocketmq.broker.offset; package org.apache.rocketmq.broker.offset;
......
...@@ -16,7 +16,7 @@ ...@@ -16,7 +16,7 @@
*/ */
/** /**
* $Id: TopicConfigManagerTest.java 1831 2013-05-16 01:39:51Z shijia.wxr $ * $Id: TopicConfigManagerTest.java 1831 2013-05-16 01:39:51Z vintagewang@apache.org $
*/ */
package org.apache.rocketmq.broker.topic; package org.apache.rocketmq.broker.topic;
......
...@@ -24,8 +24,8 @@ import org.apache.rocketmq.remoting.common.RemotingUtil; ...@@ -24,8 +24,8 @@ import org.apache.rocketmq.remoting.common.RemotingUtil;
/** /**
* Client Common configuration * Client Common configuration
* *
* @author shijia.wxr * @author vintagewang@apache.org
* @author vongosling * @author vongosling@apache.org
*/ */
public class ClientConfig { public class ClientConfig {
public static final String SEND_MESSAGE_WITH_VIP_CHANNEL_PROPERTY = "com.rocketmq.sendMessageWithVIPChannel"; public static final String SEND_MESSAGE_WITH_VIP_CHANNEL_PROPERTY = "com.rocketmq.sendMessageWithVIPChannel";
......
...@@ -26,7 +26,7 @@ import org.apache.rocketmq.remoting.exception.RemotingException; ...@@ -26,7 +26,7 @@ import org.apache.rocketmq.remoting.exception.RemotingException;
/** /**
* Base interface for MQ management * Base interface for MQ management
* *
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public interface MQAdmin { public interface MQAdmin {
/** /**
......
...@@ -27,7 +27,7 @@ import java.util.TreeSet; ...@@ -27,7 +27,7 @@ import java.util.TreeSet;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class MQHelper { public class MQHelper {
public static void resetOffsetByTimestamp( public static void resetOffsetByTimestamp(
......
...@@ -22,7 +22,7 @@ import java.util.List; ...@@ -22,7 +22,7 @@ import java.util.List;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class QueryResult { public class QueryResult {
private final long indexLastUpdateTimestamp; private final long indexLastUpdateTimestamp;
......
...@@ -17,7 +17,7 @@ ...@@ -17,7 +17,7 @@
package org.apache.rocketmq.client.admin; package org.apache.rocketmq.client.admin;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public interface MQAdminExtInner { public interface MQAdminExtInner {
......
...@@ -24,8 +24,8 @@ import java.util.List; ...@@ -24,8 +24,8 @@ import java.util.List;
/** /**
* Strategy Algorithm for message allocating between consumers * Strategy Algorithm for message allocating between consumers
* *
* @author shijia.wxr * @author vintagewang@apache.org
* @author vongosling * @author vongosling@apache.org
*/ */
public interface AllocateMessageQueueStrategy { public interface AllocateMessageQueueStrategy {
......
...@@ -38,7 +38,7 @@ import java.util.Set; ...@@ -38,7 +38,7 @@ import java.util.Set;
/** /**
* Default pulling consumer * Default pulling consumer
* *
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class DefaultMQPullConsumer extends ClientConfig implements MQPullConsumer { public class DefaultMQPullConsumer extends ClientConfig implements MQPullConsumer {
protected final transient DefaultMQPullConsumerImpl defaultMQPullConsumerImpl; protected final transient DefaultMQPullConsumerImpl defaultMQPullConsumerImpl;
......
...@@ -44,7 +44,7 @@ import java.util.Set; ...@@ -44,7 +44,7 @@ import java.util.Set;
/** /**
* Wrapped push consumer.in fact,it works as remarkable as the pull consumer * Wrapped push consumer.in fact,it works as remarkable as the pull consumer
* *
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class DefaultMQPushConsumer extends ClientConfig implements MQPushConsumer { public class DefaultMQPushConsumer extends ClientConfig implements MQPushConsumer {
protected final transient DefaultMQPushConsumerImpl defaultMQPushConsumerImpl; protected final transient DefaultMQPushConsumerImpl defaultMQPushConsumerImpl;
......
...@@ -29,7 +29,7 @@ import java.util.Set; ...@@ -29,7 +29,7 @@ import java.util.Set;
/** /**
* Message queue consumer interface * Message queue consumer interface
* *
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public interface MQConsumer extends MQAdmin { public interface MQConsumer extends MQAdmin {
/** /**
......
...@@ -28,7 +28,7 @@ import java.util.Set; ...@@ -28,7 +28,7 @@ import java.util.Set;
/** /**
* Pulling consumer interface * Pulling consumer interface
* *
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public interface MQPullConsumer extends MQConsumer { public interface MQPullConsumer extends MQConsumer {
/** /**
......
...@@ -34,7 +34,7 @@ import java.util.concurrent.TimeUnit; ...@@ -34,7 +34,7 @@ import java.util.concurrent.TimeUnit;
/** /**
* Schedule service for pull consumer * Schedule service for pull consumer
* *
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class MQPullConsumerScheduleService { public class MQPullConsumerScheduleService {
private final Logger log = ClientLogger.getLog(); private final Logger log = ClientLogger.getLog();
......
...@@ -25,7 +25,7 @@ import org.apache.rocketmq.client.exception.MQClientException; ...@@ -25,7 +25,7 @@ import org.apache.rocketmq.client.exception.MQClientException;
/** /**
* Push consumer * Push consumer
* *
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public interface MQPushConsumer extends MQConsumer { public interface MQPushConsumer extends MQConsumer {
/** /**
......
...@@ -24,8 +24,8 @@ import java.util.Set; ...@@ -24,8 +24,8 @@ import java.util.Set;
/** /**
* A MessageQueueListener is implemented by the application and may be specified when a message queue changed * A MessageQueueListener is implemented by the application and may be specified when a message queue changed
* *
* @author shijia.wxr * @author vintagewang@apache.org
* @author vongosling * @author vongosling@apache.org
*/ */
public interface MessageQueueListener { public interface MessageQueueListener {
/** /**
......
...@@ -19,7 +19,7 @@ package org.apache.rocketmq.client.consumer; ...@@ -19,7 +19,7 @@ package org.apache.rocketmq.client.consumer;
/** /**
* Async message pulling interface * Async message pulling interface
* *
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public interface PullCallback { public interface PullCallback {
public void onSuccess(final PullResult pullResult); public void onSuccess(final PullResult pullResult);
......
...@@ -22,7 +22,7 @@ import java.util.List; ...@@ -22,7 +22,7 @@ import java.util.List;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class PullResult { public class PullResult {
private final PullStatus pullStatus; private final PullStatus pullStatus;
......
...@@ -17,7 +17,7 @@ ...@@ -17,7 +17,7 @@
package org.apache.rocketmq.client.consumer; package org.apache.rocketmq.client.consumer;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public enum PullStatus { public enum PullStatus {
/** /**
......
...@@ -22,7 +22,7 @@ import org.apache.rocketmq.common.message.MessageQueue; ...@@ -22,7 +22,7 @@ import org.apache.rocketmq.common.message.MessageQueue;
/** /**
* Consumer concurrent consumption context * Consumer concurrent consumption context
* *
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class ConsumeConcurrentlyContext { public class ConsumeConcurrentlyContext {
private final MessageQueue messageQueue; private final MessageQueue messageQueue;
......
...@@ -17,7 +17,7 @@ ...@@ -17,7 +17,7 @@
package org.apache.rocketmq.client.consumer.listener; package org.apache.rocketmq.client.consumer.listener;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public enum ConsumeConcurrentlyStatus { public enum ConsumeConcurrentlyStatus {
/** /**
......
...@@ -22,7 +22,7 @@ import org.apache.rocketmq.common.message.MessageQueue; ...@@ -22,7 +22,7 @@ import org.apache.rocketmq.common.message.MessageQueue;
/** /**
* Consumer Orderly consumption context * Consumer Orderly consumption context
* *
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class ConsumeOrderlyContext { public class ConsumeOrderlyContext {
private final MessageQueue messageQueue; private final MessageQueue messageQueue;
......
...@@ -17,7 +17,7 @@ ...@@ -17,7 +17,7 @@
package org.apache.rocketmq.client.consumer.listener; package org.apache.rocketmq.client.consumer.listener;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public enum ConsumeOrderlyStatus { public enum ConsumeOrderlyStatus {
/** /**
......
...@@ -19,7 +19,7 @@ package org.apache.rocketmq.client.consumer.listener; ...@@ -19,7 +19,7 @@ package org.apache.rocketmq.client.consumer.listener;
/** /**
* A MessageListener object is used to receive asynchronously delivered messages. * A MessageListener object is used to receive asynchronously delivered messages.
* *
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public interface MessageListener { public interface MessageListener {
} }
...@@ -24,7 +24,7 @@ import java.util.List; ...@@ -24,7 +24,7 @@ import java.util.List;
/** /**
* A MessageListenerConcurrently object is used to receive asynchronously delivered messages concurrently * A MessageListenerConcurrently object is used to receive asynchronously delivered messages concurrently
* *
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public interface MessageListenerConcurrently extends MessageListener { public interface MessageListenerConcurrently extends MessageListener {
/** /**
......
...@@ -24,7 +24,7 @@ import java.util.List; ...@@ -24,7 +24,7 @@ import java.util.List;
/** /**
* A MessageListenerConcurrently object is used to receive asynchronously delivered messages orderly.one queue,one thread * A MessageListenerConcurrently object is used to receive asynchronously delivered messages orderly.one queue,one thread
* *
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public interface MessageListenerOrderly extends MessageListener { public interface MessageListenerOrderly extends MessageListener {
/** /**
......
...@@ -23,7 +23,7 @@ import java.util.List; ...@@ -23,7 +23,7 @@ import java.util.List;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class AllocateMessageQueueByConfig implements AllocateMessageQueueStrategy { public class AllocateMessageQueueByConfig implements AllocateMessageQueueStrategy {
private List<MessageQueue> messageQueueList; private List<MessageQueue> messageQueueList;
......
...@@ -39,7 +39,7 @@ import java.util.concurrent.atomic.AtomicLong; ...@@ -39,7 +39,7 @@ import java.util.concurrent.atomic.AtomicLong;
/** /**
* Local storage implementation * Local storage implementation
* *
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class LocalFileOffsetStore implements OffsetStore { public class LocalFileOffsetStore implements OffsetStore {
public final static String LOCAL_OFFSET_STORE_DIR = System.getProperty( public final static String LOCAL_OFFSET_STORE_DIR = System.getProperty(
......
...@@ -26,7 +26,7 @@ import java.util.concurrent.atomic.AtomicLong; ...@@ -26,7 +26,7 @@ import java.util.concurrent.atomic.AtomicLong;
/** /**
* Wrapper class for offset serialization * Wrapper class for offset serialization
* *
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class OffsetSerializeWrapper extends RemotingSerializable { public class OffsetSerializeWrapper extends RemotingSerializable {
private ConcurrentHashMap<MessageQueue, AtomicLong> offsetTable = private ConcurrentHashMap<MessageQueue, AtomicLong> offsetTable =
......
...@@ -28,7 +28,7 @@ import java.util.Set; ...@@ -28,7 +28,7 @@ import java.util.Set;
/** /**
* Offset store interface * Offset store interface
* *
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public interface OffsetStore { public interface OffsetStore {
/** /**
......
...@@ -40,7 +40,7 @@ import java.util.concurrent.atomic.AtomicLong; ...@@ -40,7 +40,7 @@ import java.util.concurrent.atomic.AtomicLong;
/** /**
* Remote storage implementation * Remote storage implementation
* *
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class RemoteBrokerOffsetStore implements OffsetStore { public class RemoteBrokerOffsetStore implements OffsetStore {
private final static Logger log = ClientLogger.getLog(); private final static Logger log = ClientLogger.getLog();
......
...@@ -21,7 +21,7 @@ import org.apache.rocketmq.common.help.FAQUrl; ...@@ -21,7 +21,7 @@ import org.apache.rocketmq.common.help.FAQUrl;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class MQBrokerException extends Exception { public class MQBrokerException extends Exception {
private static final long serialVersionUID = 5975020272601250368L; private static final long serialVersionUID = 5975020272601250368L;
......
...@@ -21,7 +21,7 @@ import org.apache.rocketmq.common.help.FAQUrl; ...@@ -21,7 +21,7 @@ import org.apache.rocketmq.common.help.FAQUrl;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class MQClientException extends Exception { public class MQClientException extends Exception {
private static final long serialVersionUID = -5758410930844185841L; private static final long serialVersionUID = -5758410930844185841L;
......
...@@ -44,7 +44,7 @@ import java.util.Map; ...@@ -44,7 +44,7 @@ import java.util.Map;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class ClientRemotingProcessor implements NettyRequestProcessor { public class ClientRemotingProcessor implements NettyRequestProcessor {
private final Logger log = ClientLogger.getLog(); private final Logger log = ClientLogger.getLog();
......
...@@ -17,7 +17,7 @@ ...@@ -17,7 +17,7 @@
package org.apache.rocketmq.client.impl; package org.apache.rocketmq.client.impl;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public enum CommunicationMode { public enum CommunicationMode {
SYNC, SYNC,
......
...@@ -17,7 +17,7 @@ ...@@ -17,7 +17,7 @@
package org.apache.rocketmq.client.impl; package org.apache.rocketmq.client.impl;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class FindBrokerResult { public class FindBrokerResult {
private final String brokerAddr; private final String brokerAddr;
......
...@@ -49,7 +49,7 @@ import java.util.concurrent.TimeUnit; ...@@ -49,7 +49,7 @@ import java.util.concurrent.TimeUnit;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class MQAdminImpl { public class MQAdminImpl {
......
...@@ -67,7 +67,7 @@ import java.util.concurrent.atomic.AtomicInteger; ...@@ -67,7 +67,7 @@ import java.util.concurrent.atomic.AtomicInteger;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class MQClientAPIImpl { public class MQClientAPIImpl {
......
...@@ -25,7 +25,7 @@ import java.util.concurrent.atomic.AtomicInteger; ...@@ -25,7 +25,7 @@ import java.util.concurrent.atomic.AtomicInteger;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class MQClientManager { public class MQClientManager {
private static MQClientManager instance = new MQClientManager(); private static MQClientManager instance = new MQClientManager();
......
...@@ -40,7 +40,7 @@ import java.util.concurrent.*; ...@@ -40,7 +40,7 @@ import java.util.concurrent.*;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class ConsumeMessageConcurrentlyService implements ConsumeMessageService { public class ConsumeMessageConcurrentlyService implements ConsumeMessageService {
private static final Logger log = ClientLogger.getLog(); private static final Logger log = ClientLogger.getLog();
......
...@@ -42,7 +42,7 @@ import java.util.concurrent.*; ...@@ -42,7 +42,7 @@ import java.util.concurrent.*;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class ConsumeMessageOrderlyService implements ConsumeMessageService { public class ConsumeMessageOrderlyService implements ConsumeMessageService {
private static final Logger log = ClientLogger.getLog(); private static final Logger log = ClientLogger.getLog();
......
...@@ -24,7 +24,7 @@ import java.util.List; ...@@ -24,7 +24,7 @@ import java.util.List;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public interface ConsumeMessageService { public interface ConsumeMessageService {
void start(); void start();
......
...@@ -57,7 +57,7 @@ import java.util.concurrent.ConcurrentHashMap; ...@@ -57,7 +57,7 @@ import java.util.concurrent.ConcurrentHashMap;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class DefaultMQPullConsumerImpl implements MQConsumerInner { public class DefaultMQPullConsumerImpl implements MQConsumerInner {
private final Logger log = ClientLogger.getLog(); private final Logger log = ClientLogger.getLog();
......
...@@ -66,7 +66,7 @@ import java.util.concurrent.ConcurrentHashMap; ...@@ -66,7 +66,7 @@ import java.util.concurrent.ConcurrentHashMap;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class DefaultMQPushConsumerImpl implements MQConsumerInner { public class DefaultMQPushConsumerImpl implements MQConsumerInner {
/** /**
......
...@@ -29,7 +29,7 @@ import java.util.Set; ...@@ -29,7 +29,7 @@ import java.util.Set;
/** /**
* Consumer inner interface * Consumer inner interface
* *
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public interface MQConsumerInner { public interface MQConsumerInner {
String groupName(); String groupName();
......
...@@ -24,7 +24,7 @@ import java.util.concurrent.ConcurrentHashMap; ...@@ -24,7 +24,7 @@ import java.util.concurrent.ConcurrentHashMap;
/** /**
* Message lock,strictly ensure the single queue only one thread at a time consuming * Message lock,strictly ensure the single queue only one thread at a time consuming
* *
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class MessageQueueLock { public class MessageQueueLock {
private ConcurrentHashMap<MessageQueue, Object> mqLockTable = private ConcurrentHashMap<MessageQueue, Object> mqLockTable =
......
...@@ -38,7 +38,7 @@ import java.util.concurrent.locks.ReentrantReadWriteLock; ...@@ -38,7 +38,7 @@ import java.util.concurrent.locks.ReentrantReadWriteLock;
/** /**
* Queue consumption snapshot * Queue consumption snapshot
* *
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class ProcessQueue { public class ProcessQueue {
public final static long REBALANCE_LOCK_MAX_LIVE_TIME = public final static long REBALANCE_LOCK_MAX_LIVE_TIME =
......
...@@ -45,7 +45,7 @@ import java.util.concurrent.atomic.AtomicLong; ...@@ -45,7 +45,7 @@ import java.util.concurrent.atomic.AtomicLong;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class PullAPIWrapper { public class PullAPIWrapper {
private final Logger log = ClientLogger.getLog(); private final Logger log = ClientLogger.getLog();
......
...@@ -25,7 +25,7 @@ import java.util.concurrent.*; ...@@ -25,7 +25,7 @@ import java.util.concurrent.*;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class PullMessageService extends ServiceThread { public class PullMessageService extends ServiceThread {
private final Logger log = ClientLogger.getLog(); private final Logger log = ClientLogger.getLog();
......
...@@ -20,7 +20,7 @@ import org.apache.rocketmq.common.message.MessageQueue; ...@@ -20,7 +20,7 @@ import org.apache.rocketmq.common.message.MessageQueue;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class PullRequest { public class PullRequest {
private String consumerGroup; private String consumerGroup;
......
...@@ -24,7 +24,7 @@ import java.util.List; ...@@ -24,7 +24,7 @@ import java.util.List;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class PullResultExt extends PullResult { public class PullResultExt extends PullResult {
private final long suggestWhichBrokerId; private final long suggestWhichBrokerId;
......
...@@ -37,7 +37,7 @@ import java.util.concurrent.ConcurrentHashMap; ...@@ -37,7 +37,7 @@ import java.util.concurrent.ConcurrentHashMap;
/** /**
* Base class for rebalance algorithm * Base class for rebalance algorithm
* *
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public abstract class RebalanceImpl { public abstract class RebalanceImpl {
protected static final Logger log = ClientLogger.getLog(); protected static final Logger log = ClientLogger.getLog();
......
...@@ -28,7 +28,7 @@ import java.util.Set; ...@@ -28,7 +28,7 @@ import java.util.Set;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class RebalancePullImpl extends RebalanceImpl { public class RebalancePullImpl extends RebalanceImpl {
private final DefaultMQPullConsumerImpl defaultMQPullConsumerImpl; private final DefaultMQPullConsumerImpl defaultMQPullConsumerImpl;
......
...@@ -34,7 +34,7 @@ import java.util.concurrent.TimeUnit; ...@@ -34,7 +34,7 @@ import java.util.concurrent.TimeUnit;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class RebalancePushImpl extends RebalanceImpl { public class RebalancePushImpl extends RebalanceImpl {
private final static long UNLOCK_DELAY_TIME_MILLS = Long.parseLong(System.getProperty("rocketmq.client.unlockDelayTimeMills", "20000")); private final static long UNLOCK_DELAY_TIME_MILLS = Long.parseLong(System.getProperty("rocketmq.client.unlockDelayTimeMills", "20000"));
......
...@@ -25,7 +25,7 @@ import org.slf4j.Logger; ...@@ -25,7 +25,7 @@ import org.slf4j.Logger;
/** /**
* Rebalance Service * Rebalance Service
* *
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class RebalanceService extends ServiceThread { public class RebalanceService extends ServiceThread {
private static long waitInterval = private static long waitInterval =
......
...@@ -59,7 +59,7 @@ import java.util.concurrent.locks.ReentrantLock; ...@@ -59,7 +59,7 @@ import java.util.concurrent.locks.ReentrantLock;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class MQClientInstance { public class MQClientInstance {
private final static long LOCK_TIMEOUT_MILLIS = 3000; private final static long LOCK_TIMEOUT_MILLIS = 3000;
......
...@@ -55,7 +55,7 @@ import java.util.concurrent.*; ...@@ -55,7 +55,7 @@ import java.util.concurrent.*;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class DefaultMQProducerImpl implements MQProducerInner { public class DefaultMQProducerImpl implements MQProducerInner {
private final Logger log = ClientLogger.getLog(); private final Logger log = ClientLogger.getLog();
......
...@@ -24,7 +24,7 @@ import java.util.Set; ...@@ -24,7 +24,7 @@ import java.util.Set;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public interface MQProducerInner { public interface MQProducerInner {
Set<String> getPublishTopicList(); Set<String> getPublishTopicList();
......
...@@ -26,7 +26,7 @@ import java.util.List; ...@@ -26,7 +26,7 @@ import java.util.List;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public class TopicPublishInfo { public class TopicPublishInfo {
private boolean orderTopic = false; private boolean orderTopic = false;
......
...@@ -18,7 +18,7 @@ ...@@ -18,7 +18,7 @@
package org.apache.rocketmq.client.latency; package org.apache.rocketmq.client.latency;
/** /**
* @author shijia.wxr * @author vintagewang@apache.org
*/ */
public interface LatencyFaultTolerance<T> { public interface LatencyFaultTolerance<T> {
void updateFaultItem(final T name, final long currentLatency, final long notAvailableDuration); void updateFaultItem(final T name, final long currentLatency, final long notAvailableDuration);
......
此差异已折叠。
Markdown is supported
0% .
You are about to add 0 people to the discussion. Proceed with caution.
先完成此消息的编辑!
想要评论请 注册