You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@rocketmq.apache.org by yu...@apache.org on 2016/12/29 03:56:24 UTC

[10/10] incubator-rocketmq git commit: ROCKETMQ-18 Polish copyright and remove unnecessary code.

ROCKETMQ-18 Polish copyright and remove unnecessary code.


Project: http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/commit/f9d90201
Tree: http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/tree/f9d90201
Diff: http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/diff/f9d90201

Branch: refs/heads/master
Commit: f9d90201d023adfa39157c6b11f7a8cd50de5d43
Parents: 2eae25c
Author: yukon <yu...@apache.org>
Authored: Thu Dec 29 11:44:14 2016 +0800
Committer: yukon <yu...@apache.org>
Committed: Thu Dec 29 11:53:38 2016 +0800

----------------------------------------------------------------------
 benchmark/consumer.sh                           | 10 ++++-----
 benchmark/producer.sh                           | 14 ++++++-------
 benchmark/runclass.sh                           | 15 ++++++-------
 benchmark/tproducer.sh                          | 14 ++++++-------
 bin/cachedog.sh                                 | 10 ++++-----
 bin/cleancache.sh                               | 10 ++++-----
 bin/cleancache.v1.sh                            | 10 ++++-----
 bin/mqadmin                                     | 10 ++++-----
 bin/mqadmin.xml                                 | 10 ++++-----
 bin/mqbroker                                    | 10 ++++-----
 bin/mqbroker.numanode0                          | 10 ++++-----
 bin/mqbroker.numanode1                          | 10 ++++-----
 bin/mqbroker.numanode2                          | 10 ++++-----
 bin/mqbroker.numanode3                          | 10 ++++-----
 bin/mqbroker.xml                                | 10 ++++-----
 bin/mqfiltersrv                                 | 10 ++++-----
 bin/mqfiltersrv.xml                             | 10 ++++-----
 bin/mqnamesrv                                   | 10 ++++-----
 bin/mqnamesrv.xml                               | 10 ++++-----
 bin/mqshutdown                                  | 10 ++++-----
 bin/os.sh                                       | 14 +++++--------
 bin/play.sh                                     | 10 ++++-----
 bin/runbroker.sh                                | 10 ++++-----
 bin/runserver.sh                                | 10 ++++-----
 bin/setcache.sh                                 | 10 ++++-----
 bin/startfsrv.sh                                | 10 ++++-----
 bin/tools.sh                                    | 10 ++++-----
 broker/pom.xml                                  | 10 ++++-----
 .../rocketmq/broker/BrokerController.java       |  8 +++----
 .../rocketmq/broker/BrokerPathConfigHelper.java |  4 ++--
 .../apache/rocketmq/broker/BrokerStartup.java   |  4 ++--
 .../broker/client/ClientChannelInfo.java        |  4 ++--
 .../client/ClientHousekeepingService.java       |  4 ++--
 .../broker/client/ConsumerGroupInfo.java        |  4 ++--
 .../client/ConsumerIdsChangeListener.java       |  4 ++--
 .../rocketmq/broker/client/ConsumerManager.java |  8 +++----
 .../DefaultConsumerIdsChangeListener.java       |  4 ++--
 .../rocketmq/broker/client/ProducerManager.java |  4 ++--
 .../broker/client/net/Broker2Client.java        |  8 +++----
 .../client/rebalance/RebalanceLockManager.java  |  4 ++--
 .../broker/filtersrv/FilterServerManager.java   |  4 ++--
 .../broker/filtersrv/FilterServerUtil.java      |  4 ++--
 .../broker/latency/BrokerFastFailure.java       |  4 ++--
 .../latency/BrokerFixedThreadPoolExecutor.java  |  4 ++--
 .../rocketmq/broker/latency/FutureTaskExt.java  |  4 ++--
 .../broker/longpolling/ManyPullRequest.java     |  4 ++--
 .../NotifyMessageArrivingListener.java          |  4 ++--
 .../broker/longpolling/PullRequest.java         |  4 ++--
 .../longpolling/PullRequestHoldService.java     |  8 +++----
 .../broker/mqtrace/ConsumeMessageContext.java   |  4 ++--
 .../broker/mqtrace/ConsumeMessageHook.java      |  4 ++--
 .../broker/mqtrace/SendMessageContext.java      |  4 ++--
 .../broker/mqtrace/SendMessageHook.java         |  4 ++--
 .../broker/offset/ConsumerOffsetManager.java    |  4 ++--
 .../rocketmq/broker/out/BrokerOuterAPI.java     |  4 ++--
 .../broker/pagecache/ManyMessageTransfer.java   |  4 ++--
 .../broker/pagecache/OneMessageTransfer.java    |  4 ++--
 .../broker/pagecache/QueryMessageTransfer.java  |  4 ++--
 .../plugin/AbstractPluginMessageStore.java      |  7 ++-----
 .../broker/plugin/MessageStoreFactory.java      |  7 ++-----
 .../plugin/MessageStorePluginContext.java       |  7 ++-----
 .../processor/AbstractSendMessageProcessor.java |  4 ++--
 .../broker/processor/AdminBrokerProcessor.java  |  8 +++----
 .../broker/processor/ClientManageProcessor.java |  8 +++----
 .../processor/ConsumerManageProcessor.java      |  8 +++----
 .../processor/EndTransactionProcessor.java      |  4 ++--
 .../processor/ForwardRequestProcessor.java      |  4 ++--
 .../broker/processor/PullMessageProcessor.java  |  8 +++----
 .../broker/processor/QueryMessageProcessor.java |  4 ++--
 .../broker/processor/SendMessageProcessor.java  |  4 ++--
 .../rocketmq/broker/slave/SlaveSynchronize.java |  4 ++--
 .../subscription/SubscriptionGroupManager.java  |  4 ++--
 .../broker/topic/TopicConfigManager.java        |  4 ++--
 .../broker/transaction/TransactionRecord.java   |  4 ++--
 .../broker/transaction/TransactionStore.java    |  4 ++--
 .../transaction/jdbc/JDBCTransactionStore.java  |  4 ++--
 .../jdbc/JDBCTransactionStoreConfig.java        |  4 ++--
 .../rocketmq/broker/BrokerControllerTest.java   |  4 ++--
 .../rocketmq/broker/BrokerTestHarness.java      |  8 ++-----
 .../rocketmq/broker/api/SendMessageTest.java    |  8 ++-----
 .../offset/ConsumerOffsetManagerTest.java       |  8 ++-----
 .../broker/topic/TopicConfigManagerTest.java    |  8 ++-----
 broker/src/test/resources/logback-test.xml      | 10 ++++-----
 client/pom.xml                                  | 12 +++++------
 .../apache/rocketmq/client/ClientConfig.java    |  4 ++--
 .../org/apache/rocketmq/client/MQAdmin.java     |  4 ++--
 .../org/apache/rocketmq/client/MQHelper.java    |  4 ++--
 .../org/apache/rocketmq/client/QueryResult.java |  4 ++--
 .../org/apache/rocketmq/client/Validators.java  |  4 ++--
 .../rocketmq/client/admin/MQAdminExtInner.java  |  4 ++--
 .../rocketmq/client/common/ClientErrorCode.java |  4 ++--
 .../client/common/ThreadLocalIndex.java         |  4 ++--
 .../consumer/AllocateMessageQueueStrategy.java  |  4 ++--
 .../client/consumer/DefaultMQPullConsumer.java  |  4 ++--
 .../client/consumer/DefaultMQPushConsumer.java  |  4 ++--
 .../rocketmq/client/consumer/MQConsumer.java    |  4 ++--
 .../client/consumer/MQPullConsumer.java         |  4 ++--
 .../consumer/MQPullConsumerScheduleService.java |  4 ++--
 .../client/consumer/MQPushConsumer.java         |  4 ++--
 .../client/consumer/MessageQueueListener.java   |  4 ++--
 .../rocketmq/client/consumer/PullCallback.java  |  4 ++--
 .../rocketmq/client/consumer/PullResult.java    |  4 ++--
 .../rocketmq/client/consumer/PullStatus.java    |  4 ++--
 .../client/consumer/PullTaskCallback.java       |  4 ++--
 .../client/consumer/PullTaskContext.java        |  4 ++--
 .../listener/ConsumeConcurrentlyContext.java    |  4 ++--
 .../listener/ConsumeConcurrentlyStatus.java     |  4 ++--
 .../listener/ConsumeOrderlyContext.java         |  4 ++--
 .../consumer/listener/ConsumeOrderlyStatus.java |  4 ++--
 .../consumer/listener/ConsumeReturnType.java    |  4 ++--
 .../consumer/listener/MessageListener.java      |  4 ++--
 .../listener/MessageListenerConcurrently.java   |  4 ++--
 .../listener/MessageListenerOrderly.java        |  4 ++--
 .../AllocateMessageQueueAveragely.java          |  4 ++--
 .../AllocateMessageQueueAveragelyByCircle.java  |  4 ++--
 .../rebalance/AllocateMessageQueueByConfig.java |  4 ++--
 .../AllocateMessageQueueByMachineRoom.java      |  4 ++--
 .../consumer/store/LocalFileOffsetStore.java    |  4 ++--
 .../consumer/store/OffsetSerializeWrapper.java  |  4 ++--
 .../client/consumer/store/OffsetStore.java      |  4 ++--
 .../client/consumer/store/ReadOffsetType.java   |  4 ++--
 .../consumer/store/RemoteBrokerOffsetStore.java |  4 ++--
 .../client/exception/MQBrokerException.java     |  4 ++--
 .../client/exception/MQClientException.java     |  4 ++--
 .../client/hook/CheckForbiddenContext.java      |  4 ++--
 .../client/hook/CheckForbiddenHook.java         |  4 ++--
 .../client/hook/ConsumeMessageContext.java      |  4 ++--
 .../client/hook/ConsumeMessageHook.java         |  4 ++--
 .../client/hook/FilterMessageContext.java       |  4 ++--
 .../rocketmq/client/hook/FilterMessageHook.java |  4 ++--
 .../client/hook/SendMessageContext.java         |  4 ++--
 .../rocketmq/client/hook/SendMessageHook.java   |  4 ++--
 .../client/impl/ClientRemotingProcessor.java    |  4 ++--
 .../rocketmq/client/impl/CommunicationMode.java |  4 ++--
 .../rocketmq/client/impl/FindBrokerResult.java  |  4 ++--
 .../rocketmq/client/impl/MQAdminImpl.java       |  4 ++--
 .../rocketmq/client/impl/MQClientAPIImpl.java   |  4 ++--
 .../rocketmq/client/impl/MQClientManager.java   |  4 ++--
 .../ConsumeMessageConcurrentlyService.java      |  4 ++--
 .../consumer/ConsumeMessageOrderlyService.java  |  4 ++--
 .../impl/consumer/ConsumeMessageService.java    |  4 ++--
 .../consumer/DefaultMQPullConsumerImpl.java     |  8 +++----
 .../consumer/DefaultMQPushConsumerImpl.java     |  8 +++----
 .../client/impl/consumer/MQConsumerInner.java   |  4 ++--
 .../client/impl/consumer/MessageQueueLock.java  |  4 ++--
 .../client/impl/consumer/ProcessQueue.java      |  4 ++--
 .../client/impl/consumer/PullAPIWrapper.java    |  4 ++--
 .../impl/consumer/PullMessageService.java       |  4 ++--
 .../client/impl/consumer/PullRequest.java       |  4 ++--
 .../client/impl/consumer/PullResultExt.java     |  4 ++--
 .../client/impl/consumer/RebalanceImpl.java     |  8 +++----
 .../client/impl/consumer/RebalancePullImpl.java |  4 ++--
 .../client/impl/consumer/RebalancePushImpl.java |  4 ++--
 .../client/impl/consumer/RebalanceService.java  |  4 ++--
 .../client/impl/factory/MQClientInstance.java   |  4 ++--
 .../impl/producer/DefaultMQProducerImpl.java    |  4 ++--
 .../client/impl/producer/MQProducerInner.java   |  4 ++--
 .../client/impl/producer/TopicPublishInfo.java  |  4 ++--
 .../client/latency/LatencyFaultTolerance.java   |  4 ++--
 .../latency/LatencyFaultToleranceImpl.java      |  4 ++--
 .../client/latency/MQFaultStrategy.java         |  4 ++--
 .../rocketmq/client/log/ClientLogger.java       |  4 ++--
 .../client/producer/DefaultMQProducer.java      |  4 ++--
 .../producer/LocalTransactionExecuter.java      |  4 ++--
 .../client/producer/LocalTransactionState.java  |  4 ++--
 .../rocketmq/client/producer/MQProducer.java    |  4 ++--
 .../client/producer/MessageQueueSelector.java   |  4 ++--
 .../rocketmq/client/producer/SendCallback.java  |  4 ++--
 .../rocketmq/client/producer/SendResult.java    |  4 ++--
 .../rocketmq/client/producer/SendStatus.java    |  4 ++--
 .../producer/TransactionCheckListener.java      |  4 ++--
 .../client/producer/TransactionMQProducer.java  |  4 ++--
 .../client/producer/TransactionSendResult.java  |  4 ++--
 .../selector/SelectMessageQueueByHash.java      |  4 ++--
 .../SelectMessageQueueByMachineRoom.java        |  4 ++--
 .../selector/SelectMessageQueueByRandoom.java   |  4 ++--
 .../client/stat/ConsumerStatsManager.java       |  4 ++--
 .../main/resources/log4j_rocketmq_client.xml    | 12 +++++------
 .../main/resources/logback_rocketmq_client.xml  | 12 +++++------
 .../apache/rocketmq/client/ValidatorsTest.java  |  4 ++--
 common/pom.xml                                  | 12 +++++------
 .../apache/rocketmq/common/BrokerConfig.java    |  8 +++----
 .../rocketmq/common/BrokerConfigSingleton.java  |  4 ++--
 .../apache/rocketmq/common/ConfigManager.java   |  4 ++--
 .../apache/rocketmq/common/Configuration.java   |  4 ++--
 .../apache/rocketmq/common/CountDownLatch2.java |  4 ++--
 .../org/apache/rocketmq/common/DataVersion.java |  4 ++--
 .../org/apache/rocketmq/common/MQVersion.java   |  8 +++----
 .../java/org/apache/rocketmq/common/MixAll.java |  4 ++--
 .../java/org/apache/rocketmq/common/Pair.java   |  4 ++--
 .../apache/rocketmq/common/ServiceState.java    |  4 ++--
 .../apache/rocketmq/common/ServiceThread.java   |  4 ++--
 .../org/apache/rocketmq/common/SystemClock.java |  4 ++--
 .../rocketmq/common/ThreadFactoryImpl.java      |  4 ++--
 .../org/apache/rocketmq/common/TopicConfig.java |  4 ++--
 .../apache/rocketmq/common/TopicFilterType.java |  4 ++--
 .../org/apache/rocketmq/common/UtilAll.java     |  4 ++--
 .../rocketmq/common/admin/ConsumeStats.java     |  4 ++--
 .../rocketmq/common/admin/OffsetWrapper.java    |  4 ++--
 .../rocketmq/common/admin/RollbackStats.java    |  7 ++-----
 .../rocketmq/common/admin/TopicOffset.java      |  4 ++--
 .../rocketmq/common/admin/TopicStatsTable.java  |  4 ++--
 .../common/annotation/ImportantField.java       |  4 ++--
 .../common/constant/DBMsgConstants.java         |  4 ++--
 .../rocketmq/common/constant/LoggerName.java    |  4 ++--
 .../rocketmq/common/constant/PermName.java      |  4 ++--
 .../common/consumer/ConsumeFromWhere.java       |  7 ++-----
 .../rocketmq/common/filter/FilterAPI.java       |  7 ++-----
 .../rocketmq/common/filter/FilterContext.java   |  4 ++--
 .../rocketmq/common/filter/MessageFilter.java   |  4 ++--
 .../apache/rocketmq/common/filter/impl/Op.java  |  4 ++--
 .../rocketmq/common/filter/impl/Operand.java    |  4 ++--
 .../rocketmq/common/filter/impl/Operator.java   |  4 ++--
 .../rocketmq/common/filter/impl/PolishExpr.java |  4 ++--
 .../rocketmq/common/filter/impl/Type.java       |  4 ++--
 .../org/apache/rocketmq/common/help/FAQUrl.java |  4 ++--
 .../rocketmq/common/hook/FilterCheckHook.java   |  4 ++--
 .../apache/rocketmq/common/message/Message.java |  4 ++--
 .../common/message/MessageAccessor.java         |  4 ++--
 .../common/message/MessageClientExt.java        |  4 ++--
 .../common/message/MessageClientIDSetter.java   |  8 +++----
 .../rocketmq/common/message/MessageConst.java   |  4 ++--
 .../rocketmq/common/message/MessageDecoder.java |  4 ++--
 .../rocketmq/common/message/MessageExt.java     |  4 ++--
 .../rocketmq/common/message/MessageId.java      |  4 ++--
 .../rocketmq/common/message/MessageQueue.java   |  4 ++--
 .../common/message/MessageQueueForC.java        |  4 ++--
 .../rocketmq/common/message/MessageType.java    |  4 ++--
 .../rocketmq/common/namesrv/NamesrvConfig.java  | 11 ++--------
 .../rocketmq/common/namesrv/NamesrvUtil.java    |  4 ++--
 .../common/namesrv/RegisterBrokerResult.java    |  4 ++--
 .../rocketmq/common/namesrv/TopAddressing.java  |  8 ++-----
 .../common/protocol/MQProtosHelper.java         |  4 ++--
 .../rocketmq/common/protocol/RequestCode.java   |  4 ++--
 .../rocketmq/common/protocol/ResponseCode.java  |  4 ++--
 .../common/protocol/body/BrokerStatsData.java   |  4 ++--
 .../common/protocol/body/BrokerStatsItem.java   |  4 ++--
 .../rocketmq/common/protocol/body/CMResult.java |  4 ++--
 .../common/protocol/body/ClusterInfo.java       |  4 ++--
 .../common/protocol/body/Connection.java        |  4 ++--
 .../common/protocol/body/ConsumeByWho.java      |  7 ++-----
 .../body/ConsumeMessageDirectlyResult.java      |  4 ++--
 .../common/protocol/body/ConsumeStatsList.java  |  4 ++--
 .../common/protocol/body/ConsumeStatus.java     |  4 ++--
 .../protocol/body/ConsumerConnection.java       |  4 ++--
 .../body/ConsumerOffsetSerializeWrapper.java    |  4 ++--
 .../protocol/body/ConsumerRunningInfo.java      |  4 ++--
 .../protocol/body/GetConsumerStatusBody.java    |  4 ++--
 .../common/protocol/body/GroupList.java         |  7 ++-----
 .../rocketmq/common/protocol/body/KVTable.java  |  7 ++-----
 .../protocol/body/LockBatchRequestBody.java     |  7 ++-----
 .../protocol/body/LockBatchResponseBody.java    |  7 ++-----
 .../common/protocol/body/ProcessQueueInfo.java  |  4 ++--
 .../protocol/body/ProducerConnection.java       |  4 ++--
 .../protocol/body/QueryConsumeTimeSpanBody.java |  4 ++--
 .../body/QueryCorrectionOffsetBody.java         |  4 ++--
 .../common/protocol/body/QueueTimeSpan.java     |  4 ++--
 .../protocol/body/RegisterBrokerBody.java       |  4 ++--
 .../common/protocol/body/ResetOffsetBody.java   |  7 ++-----
 .../protocol/body/ResetOffsetBodyForC.java      |  4 ++--
 .../protocol/body/SubscriptionGroupWrapper.java |  4 ++--
 .../body/TopicConfigSerializeWrapper.java       |  4 ++--
 .../common/protocol/body/TopicList.java         |  4 ++--
 .../protocol/body/UnlockBatchRequestBody.java   |  4 ++--
 .../CheckTransactionStateRequestHeader.java     |  8 ++-----
 .../CheckTransactionStateResponseHeader.java    |  8 ++-----
 .../header/CloneGroupOffsetRequestHeader.java   |  8 ++-----
 ...nsumeMessageDirectlyResultRequestHeader.java |  4 ++--
 .../ConsumerSendMsgBackRequestHeader.java       |  7 ++-----
 .../header/CreateTopicRequestHeader.java        |  8 ++-----
 .../DeleteSubscriptionGroupRequestHeader.java   |  4 ++--
 .../header/DeleteTopicRequestHeader.java        |  8 ++-----
 .../header/EndTransactionRequestHeader.java     |  8 ++-----
 .../header/EndTransactionResponseHeader.java    |  8 ++-----
 .../header/GetAllTopicConfigResponseHeader.java |  8 ++-----
 .../header/GetBrokerConfigResponseHeader.java   |  8 ++-----
 .../header/GetConsumeStatsInBrokerHeader.java   |  4 ++--
 .../header/GetConsumeStatsRequestHeader.java    |  4 ++--
 .../GetConsumerConnectionListRequestHeader.java |  4 ++--
 .../GetConsumerListByGroupRequestHeader.java    |  4 ++--
 .../GetConsumerListByGroupResponseBody.java     |  4 ++--
 .../GetConsumerListByGroupResponseHeader.java   |  4 ++--
 .../GetConsumerRunningInfoRequestHeader.java    |  4 ++--
 .../header/GetConsumerStatusRequestHeader.java  |  7 ++-----
 .../GetEarliestMsgStoretimeRequestHeader.java   |  8 ++-----
 .../GetEarliestMsgStoretimeResponseHeader.java  |  8 ++-----
 .../header/GetMaxOffsetRequestHeader.java       |  8 ++-----
 .../header/GetMaxOffsetResponseHeader.java      |  8 ++-----
 .../header/GetMinOffsetRequestHeader.java       |  8 ++-----
 .../header/GetMinOffsetResponseHeader.java      |  8 ++-----
 .../GetProducerConnectionListRequestHeader.java |  4 ++--
 .../header/GetTopicStatsInfoRequestHeader.java  |  7 ++-----
 .../header/GetTopicsByClusterRequestHeader.java |  7 ++-----
 .../NotifyConsumerIdsChangedRequestHeader.java  |  4 ++--
 .../header/PullMessageRequestHeader.java        |  8 ++-----
 .../header/PullMessageResponseHeader.java       |  8 ++-----
 .../QueryConsumeTimeSpanRequestHeader.java      |  7 ++-----
 .../QueryConsumerOffsetRequestHeader.java       |  8 ++-----
 .../QueryConsumerOffsetResponseHeader.java      |  8 ++-----
 .../header/QueryCorrectionOffsetHeader.java     |  8 ++-----
 .../header/QueryMessageRequestHeader.java       |  8 ++-----
 .../header/QueryMessageResponseHeader.java      |  8 ++-----
 .../QueryTopicConsumeByWhoRequestHeader.java    |  8 ++-----
 .../header/ResetOffsetRequestHeader.java        |  4 ++--
 .../header/SearchOffsetRequestHeader.java       |  8 ++-----
 .../header/SearchOffsetResponseHeader.java      |  8 ++-----
 .../header/SendMessageRequestHeader.java        |  8 ++-----
 .../header/SendMessageRequestHeaderV2.java      |  6 +++---
 .../header/SendMessageResponseHeader.java       |  8 ++-----
 .../header/UnregisterClientRequestHeader.java   |  7 ++-----
 .../header/UnregisterClientResponseHeader.java  |  7 ++-----
 .../UpdateConsumerOffsetRequestHeader.java      |  8 ++-----
 .../UpdateConsumerOffsetResponseHeader.java     |  8 ++-----
 .../ViewBrokerStatsDataRequestHeader.java       |  4 ++--
 .../header/ViewMessageRequestHeader.java        |  8 ++-----
 .../header/ViewMessageResponseHeader.java       |  8 ++-----
 .../RegisterFilterServerRequestHeader.java      |  4 ++--
 .../RegisterFilterServerResponseHeader.java     |  4 ++--
 ...RegisterMessageFilterClassRequestHeader.java |  4 ++--
 .../namesrv/DeleteKVConfigRequestHeader.java    |  7 ++-----
 .../DeleteTopicInNamesrvRequestHeader.java      |  7 ++-----
 .../namesrv/GetKVConfigRequestHeader.java       |  7 ++-----
 .../namesrv/GetKVConfigResponseHeader.java      |  7 ++-----
 .../GetKVListByNamespaceRequestHeader.java      |  7 ++-----
 .../namesrv/GetRouteInfoRequestHeader.java      |  8 ++-----
 .../namesrv/GetRouteInfoResponseHeader.java     |  8 ++-----
 .../namesrv/PutKVConfigRequestHeader.java       |  4 ++--
 .../namesrv/RegisterBrokerRequestHeader.java    |  8 ++-----
 .../namesrv/RegisterBrokerResponseHeader.java   |  7 ++-----
 .../RegisterOrderTopicRequestHeader.java        |  8 ++-----
 .../namesrv/UnRegisterBrokerRequestHeader.java  |  8 ++-----
 .../WipeWritePermOfBrokerRequestHeader.java     |  7 ++-----
 .../WipeWritePermOfBrokerResponseHeader.java    |  7 ++-----
 .../common/protocol/heartbeat/ConsumeType.java  |  8 ++-----
 .../common/protocol/heartbeat/ConsumerData.java |  8 ++-----
 .../protocol/heartbeat/HeartbeatData.java       |  8 ++-----
 .../common/protocol/heartbeat/MessageModel.java |  8 ++-----
 .../common/protocol/heartbeat/ProducerData.java |  8 ++-----
 .../protocol/heartbeat/SubscriptionData.java    |  8 ++-----
 .../common/protocol/route/BrokerData.java       | 11 ++--------
 .../common/protocol/route/QueueData.java        |  8 ++-----
 .../common/protocol/route/TopicRouteData.java   |  8 ++-----
 .../common/protocol/topic/OffsetMovedEvent.java |  4 ++--
 .../common/queue/ConcurrentTreeMap.java         |  4 ++--
 .../rocketmq/common/queue/RoundQueue.java       |  4 ++--
 .../rocketmq/common/running/RunningStats.java   |  4 ++--
 .../rocketmq/common/stats/MomentStatsItem.java  |  4 ++--
 .../common/stats/MomentStatsItemSet.java        |  4 ++--
 .../apache/rocketmq/common/stats/StatsItem.java |  4 ++--
 .../rocketmq/common/stats/StatsItemSet.java     |  4 ++--
 .../rocketmq/common/stats/StatsSnapshot.java    |  4 ++--
 .../subscription/SubscriptionGroupConfig.java   |  4 ++--
 .../rocketmq/common/sysflag/MessageSysFlag.java |  4 ++--
 .../rocketmq/common/sysflag/PullSysFlag.java    |  4 ++--
 .../common/sysflag/SubscriptionSysFlag.java     |  4 ++--
 .../rocketmq/common/sysflag/TopicSysFlag.java   |  4 ++--
 .../rocketmq/common/utils/ChannelUtil.java      |  4 ++--
 .../rocketmq/common/utils/HttpTinyClient.java   |  4 ++--
 .../rocketmq/common/utils/IOTinyUtils.java      |  4 ++--
 .../org/apache/rocketmq/common/MixAllTest.java  |  4 ++--
 .../rocketmq/common/RemotingUtilTest.java       |  4 ++--
 .../org/apache/rocketmq/common/UtilAllTest.java |  4 ++--
 .../rocketmq/common/filter/FilterAPITest.java   |  7 ++-----
 .../common/protocol/ConsumeStatusTest.java      |  4 ++--
 conf/2m-2s-async/broker-a-s.properties          | 11 +++++-----
 conf/2m-2s-async/broker-a.properties            | 11 +++++-----
 conf/2m-2s-async/broker-b-s.properties          | 11 +++++-----
 conf/2m-2s-async/broker-b.properties            | 11 +++++-----
 conf/2m-2s-sync/broker-a-s.properties           | 11 +++++-----
 conf/2m-2s-sync/broker-a.properties             | 11 +++++-----
 conf/2m-2s-sync/broker-b-s.properties           | 11 +++++-----
 conf/2m-2s-sync/broker-b.properties             | 11 +++++-----
 conf/2m-noslave/broker-a.properties             | 11 +++++-----
 conf/2m-noslave/broker-b.properties             | 11 +++++-----
 conf/logback_broker.xml                         | 10 ++++-----
 conf/logback_filtersrv.xml                      | 10 ++++-----
 conf/logback_namesrv.xml                        | 10 ++++-----
 conf/logback_tools.xml                          | 10 ++++-----
 example/pom.xml                                 | 12 +++++------
 .../rocketmq/example/benchmark/Consumer.java    |  4 ++--
 .../rocketmq/example/benchmark/Producer.java    |  4 ++--
 .../example/benchmark/TransactionProducer.java  |  4 ++--
 .../example/broadcast/PushConsumer.java         |  4 ++--
 .../rocketmq/example/filter/Consumer.java       |  4 ++--
 .../rocketmq/example/filter/Producer.java       |  4 ++--
 .../rocketmq/example/operation/Consumer.java    |  4 ++--
 .../rocketmq/example/operation/Producer.java    |  4 ++--
 .../rocketmq/example/ordermessage/Consumer.java |  4 ++--
 .../rocketmq/example/ordermessage/Producer.java |  4 ++--
 .../rocketmq/example/quickstart/Consumer.java   |  4 ++--
 .../rocketmq/example/quickstart/Producer.java   |  4 ++--
 .../rocketmq/example/simple/AsyncProducer.java  |  8 +++----
 .../rocketmq/example/simple/CachedQueue.java    |  4 ++--
 .../rocketmq/example/simple/Producer.java       |  4 ++--
 .../rocketmq/example/simple/PullConsumer.java   |  4 ++--
 .../example/simple/PullConsumerTest.java        |  4 ++--
 .../example/simple/PullScheduleService.java     |  4 ++--
 .../rocketmq/example/simple/PushConsumer.java   |  4 ++--
 .../example/simple/RandomAsyncCommit.java       |  4 ++--
 .../rocketmq/example/simple/TestProducer.java   |  4 ++--
 .../TransactionCheckListenerImpl.java           |  4 ++--
 .../transaction/TransactionExecuterImpl.java    |  4 ++--
 .../transaction/TransactionProducer.java        |  4 ++--
 filtersrv/pom.xml                               | 12 +++++------
 .../filtersrv/FilterServerOuterAPI.java         |  4 ++--
 .../rocketmq/filtersrv/FiltersrvConfig.java     |  4 ++--
 .../rocketmq/filtersrv/FiltersrvController.java |  4 ++--
 .../rocketmq/filtersrv/FiltersrvStartup.java    |  4 ++--
 .../rocketmq/filtersrv/filter/DynaCode.java     |  4 ++--
 .../filter/FilterClassFetchMethod.java          |  4 ++--
 .../filtersrv/filter/FilterClassInfo.java       |  4 ++--
 .../filtersrv/filter/FilterClassLoader.java     |  4 ++--
 .../filtersrv/filter/FilterClassManager.java    |  4 ++--
 .../filter/HttpFilterClassFetchMethod.java      |  4 ++--
 .../processor/DefaultRequestProcessor.java      |  5 +++--
 .../stats/FilterServerStatsManager.java         |  4 ++--
 namesrv/pom.xml                                 | 12 +++++------
 .../rocketmq/namesrv/NamesrvController.java     |  4 ++--
 .../apache/rocketmq/namesrv/NamesrvStartup.java |  4 ++--
 .../namesrv/kvconfig/KVConfigManager.java       |  4 ++--
 .../kvconfig/KVConfigSerializeWrapper.java      |  4 ++--
 .../processor/ClusterTestRequestProcessor.java  |  4 ++--
 .../processor/DefaultRequestProcessor.java      |  4 ++--
 .../routeinfo/BrokerHousekeepingService.java    |  4 ++--
 .../namesrv/routeinfo/RouteInfoManager.java     |  4 ++--
 pom.xml                                         | 10 ++++-----
 release-client.xml                              | 10 ++++-----
 release.xml                                     | 12 +++++------
 remoting/pom.xml                                | 12 +++++------
 .../rocketmq/remoting/ChannelEventListener.java |  7 ++-----
 .../rocketmq/remoting/CommandCustomHeader.java  |  4 ++--
 .../rocketmq/remoting/InvokeCallback.java       |  9 +++-----
 .../org/apache/rocketmq/remoting/RPCHook.java   |  8 +++----
 .../rocketmq/remoting/RemotingClient.java       |  7 ++-----
 .../rocketmq/remoting/RemotingServer.java       | 11 ++++------
 .../rocketmq/remoting/RemotingService.java      |  8 +++----
 .../rocketmq/remoting/annotation/CFNotNull.java |  4 ++--
 .../remoting/annotation/CFNullable.java         |  4 ++--
 .../apache/rocketmq/remoting/common/Pair.java   |  4 ++--
 .../remoting/common/RemotingHelper.java         |  4 ++--
 .../rocketmq/remoting/common/RemotingUtil.java  |  4 ++--
 .../common/SemaphoreReleaseOnlyOnce.java        |  4 ++--
 .../rocketmq/remoting/common/ServiceThread.java |  4 ++--
 .../exception/RemotingCommandException.java     |  4 ++--
 .../exception/RemotingConnectException.java     |  4 ++--
 .../remoting/exception/RemotingException.java   |  4 ++--
 .../exception/RemotingSendRequestException.java |  4 ++--
 .../exception/RemotingTimeoutException.java     |  4 ++--
 .../RemotingTooMuchRequestException.java        |  4 ++--
 .../remoting/netty/NettyClientConfig.java       |  7 ++-----
 .../rocketmq/remoting/netty/NettyDecoder.java   |  7 ++-----
 .../rocketmq/remoting/netty/NettyEncoder.java   |  7 ++-----
 .../rocketmq/remoting/netty/NettyEvent.java     |  4 ++--
 .../rocketmq/remoting/netty/NettyEventType.java |  7 ++-----
 .../remoting/netty/NettyRemotingAbstract.java   |  4 ++--
 .../remoting/netty/NettyRemotingClient.java     |  4 ++--
 .../remoting/netty/NettyRemotingServer.java     |  4 ++--
 .../remoting/netty/NettyRequestProcessor.java   |  4 ++--
 .../remoting/netty/NettyServerConfig.java       |  4 ++--
 .../remoting/netty/NettySystemConfig.java       |  4 ++--
 .../rocketmq/remoting/netty/RequestTask.java    |  4 ++--
 .../rocketmq/remoting/netty/ResponseFuture.java |  4 ++--
 .../remoting/protocol/LanguageCode.java         |  4 ++--
 .../remoting/protocol/RemotingCommand.java      |  4 ++--
 .../remoting/protocol/RemotingCommandType.java  |  7 ++-----
 .../remoting/protocol/RemotingSerializable.java |  7 ++-----
 .../protocol/RemotingSysResponseCode.java       |  4 ++--
 .../remoting/protocol/RocketMQSerializable.java |  7 ++-----
 .../remoting/protocol/SerializeType.java        |  4 ++--
 .../org/apache/rocketmq/remoting/MixTest.java   |  8 ++-----
 .../apache/rocketmq/remoting/NettyRPCTest.java  |  8 ++-----
 .../rocketmq/subclass/TestSubClassAuto.java     |  7 ++-----
 srvutil/pom.xml                                 | 12 +++++------
 .../org/apache/rocketmq/srvutil/ServerUtil.java |  4 ++--
 store/pom.xml                                   | 12 +++++------
 .../store/AllocateMappedFileService.java        |  4 ++--
 .../rocketmq/store/AppendMessageCallback.java   |  4 ++--
 .../rocketmq/store/AppendMessageResult.java     |  4 ++--
 .../rocketmq/store/AppendMessageStatus.java     |  4 ++--
 .../org/apache/rocketmq/store/CommitLog.java    |  4 ++--
 .../org/apache/rocketmq/store/ConsumeQueue.java |  4 ++--
 .../rocketmq/store/DefaultMessageFilter.java    |  4 ++--
 .../rocketmq/store/DefaultMessageStore.java     |  4 ++--
 .../apache/rocketmq/store/DispatchRequest.java  |  4 ++--
 .../apache/rocketmq/store/GetMessageResult.java |  4 ++--
 .../apache/rocketmq/store/GetMessageStatus.java |  4 ++--
 .../org/apache/rocketmq/store/MappedFile.java   |  4 ++--
 .../apache/rocketmq/store/MappedFileQueue.java  |  4 ++--
 .../rocketmq/store/MessageArrivingListener.java |  4 ++--
 .../rocketmq/store/MessageExtBrokerInner.java   |  4 ++--
 .../apache/rocketmq/store/MessageFilter.java    |  4 ++--
 .../org/apache/rocketmq/store/MessageStore.java |  4 ++--
 .../apache/rocketmq/store/PutMessageResult.java |  4 ++--
 .../apache/rocketmq/store/PutMessageStatus.java |  4 ++--
 .../rocketmq/store/QueryMessageResult.java      |  4 ++--
 .../rocketmq/store/ReferenceResource.java       |  4 ++--
 .../org/apache/rocketmq/store/RunningFlags.java |  4 ++--
 .../store/SelectMappedBufferResult.java         |  4 ++--
 .../apache/rocketmq/store/StoreCheckpoint.java  |  4 ++--
 .../rocketmq/store/StoreStatsService.java       |  4 ++--
 .../org/apache/rocketmq/store/StoreUtil.java    |  7 ++-----
 .../rocketmq/store/TransientStorePool.java      |  4 ++--
 .../rocketmq/store/config/BrokerRole.java       |  4 ++--
 .../rocketmq/store/config/FlushDiskType.java    |  4 ++--
 .../store/config/MessageStoreConfig.java        |  4 ++--
 .../store/config/StorePathConfigHelper.java     |  4 ++--
 .../apache/rocketmq/store/ha/HAConnection.java  |  4 ++--
 .../org/apache/rocketmq/store/ha/HAService.java |  4 ++--
 .../rocketmq/store/ha/WaitNotifyObject.java     |  4 ++--
 .../apache/rocketmq/store/index/IndexFile.java  |  4 ++--
 .../rocketmq/store/index/IndexHeader.java       |  4 ++--
 .../rocketmq/store/index/IndexService.java      |  4 ++--
 .../rocketmq/store/index/QueryOffsetResult.java |  4 ++--
 .../schedule/DelayOffsetSerializeWrapper.java   |  7 ++-----
 .../store/schedule/ScheduleMessageService.java  |  7 ++-----
 .../rocketmq/store/stats/BrokerStats.java       |  4 ++--
 .../store/stats/BrokerStatsManager.java         |  4 ++--
 .../org/apache/rocketmq/store/util/LibC.java    |  4 ++--
 .../rocketmq/store/DefaultMessageStoreTest.java |  4 ++--
 .../rocketmq/store/MappedFileQueueTest.java     |  8 ++-----
 .../apache/rocketmq/store/MappedFileTest.java   |  8 ++-----
 .../rocketmq/store/StoreCheckpointTest.java     |  8 ++-----
 .../rocketmq/store/index/IndexFileTest.java     |  8 ++-----
 .../store/schedule/ScheduleMessageTest.java     |  8 ++-----
 store/src/test/resources/logback-test.xml       | 12 +++++------
 style/copyright/Apache.xml                      | 22 +++++++++++++++++---
 style/copyright/profiles_settings.xml           | 22 +++++++++++++++++++-
 style/rmq_checkstyle.xml                        | 17 ++++++++-------
 style/rmq_codeStyle.xml                         | 17 +++++++++++++++
 tools/pom.xml                                   | 12 +++++------
 .../rocketmq/tools/admin/DefaultMQAdminExt.java |  4 ++--
 .../tools/admin/DefaultMQAdminExtImpl.java      |  4 ++--
 .../apache/rocketmq/tools/admin/MQAdminExt.java |  8 +++----
 .../rocketmq/tools/admin/api/MessageTrack.java  |  4 ++--
 .../rocketmq/tools/admin/api/TrackType.java     |  4 ++--
 .../rocketmq/tools/command/CommandUtil.java     |  4 ++--
 .../rocketmq/tools/command/MQAdminStartup.java  |  4 ++--
 .../rocketmq/tools/command/SubCommand.java      |  4 ++--
 .../broker/BrokerConsumeStatsSubCommad.java     |  4 ++--
 .../command/broker/BrokerStatusSubCommand.java  |  4 ++--
 .../broker/CleanExpiredCQSubCommand.java        |  4 ++--
 .../command/broker/CleanUnusedTopicCommand.java |  4 ++--
 .../command/broker/GetBrokerConfigCommand.java  |  4 ++--
 .../command/broker/SendMsgStatusCommand.java    |  4 ++--
 .../broker/UpdateBrokerConfigSubCommand.java    |  4 ++--
 .../cluster/CLusterSendMsgRTCommand.java        |  4 ++--
 .../command/cluster/ClusterListSubCommand.java  |  4 ++--
 .../ConsumerConnectionSubCommand.java           |  4 ++--
 .../ProducerConnectionSubCommand.java           |  4 ++--
 .../consumer/ConsumerProgressSubCommand.java    |  4 ++--
 .../consumer/ConsumerStatusSubCommand.java      |  4 ++--
 .../command/consumer/ConsumerSubCommand.java    |  4 ++--
 .../DeleteSubscriptionGroupCommand.java         |  4 ++--
 .../consumer/StartMonitoringSubCommand.java     |  4 ++--
 .../consumer/UpdateSubGroupSubCommand.java      |  4 ++--
 .../command/message/CheckMsgSendRTCommand.java  |  4 ++--
 .../command/message/DecodeMessageIdCommond.java |  4 ++--
 .../message/PrintMessageByQueueCommand.java     |  4 ++--
 .../command/message/PrintMessageSubCommand.java |  4 ++--
 .../command/message/QueryMsgByIdSubCommand.java |  4 ++--
 .../message/QueryMsgByKeySubCommand.java        |  4 ++--
 .../message/QueryMsgByOffsetSubCommand.java     |  4 ++--
 .../message/QueryMsgByUniqueKeySubCommand.java  |  4 ++--
 .../rocketmq/tools/command/message/Store.java   |  4 ++--
 .../command/namesrv/DeleteKvConfigCommand.java  |  4 ++--
 .../namesrv/GetNamesrvConfigCommand.java        |  4 ++--
 .../command/namesrv/UpdateKvConfigCommand.java  |  4 ++--
 .../namesrv/UpdateNamesrvConfigCommand.java     |  4 ++--
 .../namesrv/WipeWritePermSubCommand.java        |  4 ++--
 .../command/offset/CloneGroupOffsetCommand.java |  4 ++--
 .../offset/GetConsumerStatusCommand.java        |  4 ++--
 .../offset/ResetOffsetByTimeCommand.java        |  4 ++--
 .../offset/ResetOffsetByTimeOldCommand.java     |  4 ++--
 .../tools/command/stats/StatsAllSubCommand.java |  4 ++--
 .../command/topic/AllocateMQSubCommand.java     |  4 ++--
 .../command/topic/DeleteTopicSubCommand.java    |  4 ++--
 .../tools/command/topic/RebalanceResult.java    |  4 ++--
 .../command/topic/TopicClusterSubCommand.java   |  4 ++--
 .../command/topic/TopicListSubCommand.java      |  4 ++--
 .../command/topic/TopicRouteSubCommand.java     |  4 ++--
 .../command/topic/TopicStatusSubCommand.java    |  4 ++--
 .../command/topic/UpdateOrderConfCommand.java   |  4 ++--
 .../topic/UpdateTopicPermSubCommand.java        |  4 ++--
 .../command/topic/UpdateTopicSubCommand.java    |  4 ++--
 .../tools/monitor/DefaultMonitorListener.java   |  4 ++--
 .../rocketmq/tools/monitor/DeleteMsgsEvent.java |  4 ++--
 .../rocketmq/tools/monitor/FailedMsgs.java      |  4 ++--
 .../rocketmq/tools/monitor/MonitorConfig.java   |  4 ++--
 .../rocketmq/tools/monitor/MonitorListener.java |  8 +++----
 .../rocketmq/tools/monitor/MonitorService.java  |  4 ++--
 .../rocketmq/tools/monitor/UndoneMsgs.java      |  4 ++--
 591 files changed, 1483 insertions(+), 1796 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/benchmark/consumer.sh
----------------------------------------------------------------------
diff --git a/benchmark/consumer.sh b/benchmark/consumer.sh
index 8ab7fae..6f9cd3d 100644
--- a/benchmark/consumer.sh
+++ b/benchmark/consumer.sh
@@ -9,10 +9,10 @@
 #
 #     http://www.apache.org/licenses/LICENSE-2.0
 #
-#  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.
-#  See the License for the specific language governing permissions and
-#  limitations under the License.
+# 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.
+# See the License for the specific language governing permissions and
+# limitations under the License.
 
 sh ./runclass.sh org.apache.rocketmq.example.benchmark.Consumer $@ &

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/benchmark/producer.sh
----------------------------------------------------------------------
diff --git a/benchmark/producer.sh b/benchmark/producer.sh
index c5df34d..3116d11 100644
--- a/benchmark/producer.sh
+++ b/benchmark/producer.sh
@@ -1,4 +1,5 @@
 #!/bin/sh
+
 # Licensed to the Apache Software Foundation (ASF) under one or more
 # contributor license agreements.  See the NOTICE file distributed with
 # this work for additional information regarding copyright ownership.
@@ -8,13 +9,10 @@
 #
 #     http://www.apache.org/licenses/LICENSE-2.0
 #
-#  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.
-#  See the License for the specific language governing permissions and
-#  limitations under the License.
+# 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.
+# See the License for the specific language governing permissions and
+# limitations under the License.
 
-#
-# $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 $@ &

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/benchmark/runclass.sh
----------------------------------------------------------------------
diff --git a/benchmark/runclass.sh b/benchmark/runclass.sh
index bf4f275..13c58d1 100644
--- a/benchmark/runclass.sh
+++ b/benchmark/runclass.sh
@@ -1,4 +1,5 @@
 #!/bin/sh
+
 # Licensed to the Apache Software Foundation (ASF) under one or more
 # contributor license agreements.  See the NOTICE file distributed with
 # this work for additional information regarding copyright ownership.
@@ -8,15 +9,11 @@
 #
 #     http://www.apache.org/licenses/LICENSE-2.0
 #
-#  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.
-#  See the License for the specific language governing permissions and
-#  limitations under the License.
-
-#
-# $Id: runserver.sh 1831 2013-05-16 01:39:51Z vintagewang@apache.org $
-#
+# 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.
+# See the License for the specific language governing permissions and
+# limitations under the License.
 
 if [ $# -lt 1 ];
 then

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/benchmark/tproducer.sh
----------------------------------------------------------------------
diff --git a/benchmark/tproducer.sh b/benchmark/tproducer.sh
index 89676cc..ac4bbf3 100644
--- a/benchmark/tproducer.sh
+++ b/benchmark/tproducer.sh
@@ -1,4 +1,5 @@
 #!/bin/sh
+
 # Licensed to the Apache Software Foundation (ASF) under one or more
 # contributor license agreements.  See the NOTICE file distributed with
 # this work for additional information regarding copyright ownership.
@@ -8,13 +9,10 @@
 #
 #     http://www.apache.org/licenses/LICENSE-2.0
 #
-#  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.
-#  See the License for the specific language governing permissions and
-#  limitations under the License.
+# 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.
+# See the License for the specific language governing permissions and
+# limitations under the License.
 
-#
-# $Id: producer.sh 1831 2013-05-16 01:39:51Z vintagewang@apache.org $
-#
 sh ./runclass.sh org.apache.rocketmq.example.benchmark.TransactionProducer  $@

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/bin/cachedog.sh
----------------------------------------------------------------------
diff --git a/bin/cachedog.sh b/bin/cachedog.sh
index 049a663..9329fdb 100755
--- a/bin/cachedog.sh
+++ b/bin/cachedog.sh
@@ -9,11 +9,11 @@
 #
 #     http://www.apache.org/licenses/LICENSE-2.0
 #
-#  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.
-#  See the License for the specific language governing permissions and
-#  limitations under the License.
+# 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.
+# See the License for the specific language governing permissions and
+# limitations under the License.
 
 export PATH=$PATH:/sbin
 

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/bin/cleancache.sh
----------------------------------------------------------------------
diff --git a/bin/cleancache.sh b/bin/cleancache.sh
index 250a46b..9c6e9ab 100755
--- a/bin/cleancache.sh
+++ b/bin/cleancache.sh
@@ -9,11 +9,11 @@
 #
 #     http://www.apache.org/licenses/LICENSE-2.0
 #
-#  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.
-#  See the License for the specific language governing permissions and
-#  limitations under the License.
+# 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.
+# See the License for the specific language governing permissions and
+# limitations under the License.
 
 export PATH=$PATH:/sbin
 

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/bin/cleancache.v1.sh
----------------------------------------------------------------------
diff --git a/bin/cleancache.v1.sh b/bin/cleancache.v1.sh
index 2e21582..b334841 100755
--- a/bin/cleancache.v1.sh
+++ b/bin/cleancache.v1.sh
@@ -9,11 +9,11 @@
 #
 #     http://www.apache.org/licenses/LICENSE-2.0
 #
-#  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.
-#  See the License for the specific language governing permissions and
-#  limitations under the License.
+# 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.
+# See the License for the specific language governing permissions and
+# limitations under the License.
 
 export PATH=$PATH:/sbin
 

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/bin/mqadmin
----------------------------------------------------------------------
diff --git a/bin/mqadmin b/bin/mqadmin
index 1acd3e0..cd0253b 100644
--- a/bin/mqadmin
+++ b/bin/mqadmin
@@ -9,11 +9,11 @@
 #
 #     http://www.apache.org/licenses/LICENSE-2.0
 #
-#  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.
-#  See the License for the specific language governing permissions and
-#  limitations under the License.
+# 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.
+# See the License for the specific language governing permissions and
+# limitations under the License.
 
 if [ -z "$ROCKETMQ_HOME" ] ; then
   ## resolve links - $0 may be a link to maven's home

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/bin/mqadmin.xml
----------------------------------------------------------------------
diff --git a/bin/mqadmin.xml b/bin/mqadmin.xml
index 9c4f5ac..d014743 100644
--- a/bin/mqadmin.xml
+++ b/bin/mqadmin.xml
@@ -8,11 +8,11 @@
 
       http://www.apache.org/licenses/LICENSE-2.0
 
-   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.
-   See the License for the specific language governing permissions and
-   limitations under the License.
+  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.
+  See the License for the specific language governing permissions and
+  limitations under the License.
   -->
 
 <java>

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/bin/mqbroker
----------------------------------------------------------------------
diff --git a/bin/mqbroker b/bin/mqbroker
index 99234e2..b72310f 100644
--- a/bin/mqbroker
+++ b/bin/mqbroker
@@ -9,11 +9,11 @@
 #
 #     http://www.apache.org/licenses/LICENSE-2.0
 #
-#  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.
-#  See the License for the specific language governing permissions and
-#  limitations under the License.
+# 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.
+# See the License for the specific language governing permissions and
+# limitations under the License.
 
 if [ -z "$ROCKETMQ_HOME" ] ; then
   ## resolve links - $0 may be a link to maven's home

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/bin/mqbroker.numanode0
----------------------------------------------------------------------
diff --git a/bin/mqbroker.numanode0 b/bin/mqbroker.numanode0
index d0688a0..b7486a7 100644
--- a/bin/mqbroker.numanode0
+++ b/bin/mqbroker.numanode0
@@ -9,11 +9,11 @@
 #
 #     http://www.apache.org/licenses/LICENSE-2.0
 #
-#  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.
-#  See the License for the specific language governing permissions and
-#  limitations under the License.
+# 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.
+# See the License for the specific language governing permissions and
+# limitations under the License.
 
 if [ -z "$ROCKETMQ_HOME" ] ; then
   ## resolve links - $0 may be a link to maven's home

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/bin/mqbroker.numanode1
----------------------------------------------------------------------
diff --git a/bin/mqbroker.numanode1 b/bin/mqbroker.numanode1
index ee350d4..c301fed 100644
--- a/bin/mqbroker.numanode1
+++ b/bin/mqbroker.numanode1
@@ -9,11 +9,11 @@
 #
 #     http://www.apache.org/licenses/LICENSE-2.0
 #
-#  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.
-#  See the License for the specific language governing permissions and
-#  limitations under the License.
+# 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.
+# See the License for the specific language governing permissions and
+# limitations under the License.
 
 if [ -z "$ROCKETMQ_HOME" ] ; then
   ## resolve links - $0 may be a link to maven's home

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/bin/mqbroker.numanode2
----------------------------------------------------------------------
diff --git a/bin/mqbroker.numanode2 b/bin/mqbroker.numanode2
index 4ff2274..ea95304 100644
--- a/bin/mqbroker.numanode2
+++ b/bin/mqbroker.numanode2
@@ -9,11 +9,11 @@
 #
 #     http://www.apache.org/licenses/LICENSE-2.0
 #
-#  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.
-#  See the License for the specific language governing permissions and
-#  limitations under the License.
+# 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.
+# See the License for the specific language governing permissions and
+# limitations under the License.
 
 if [ -z "$ROCKETMQ_HOME" ] ; then
   ## resolve links - $0 may be a link to maven's home

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/bin/mqbroker.numanode3
----------------------------------------------------------------------
diff --git a/bin/mqbroker.numanode3 b/bin/mqbroker.numanode3
index 6c91d53..25d3d1d 100644
--- a/bin/mqbroker.numanode3
+++ b/bin/mqbroker.numanode3
@@ -9,11 +9,11 @@
 #
 #     http://www.apache.org/licenses/LICENSE-2.0
 #
-#  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.
-#  See the License for the specific language governing permissions and
-#  limitations under the License.
+# 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.
+# See the License for the specific language governing permissions and
+# limitations under the License.
 
 if [ -z "$ROCKETMQ_HOME" ] ; then
   ## resolve links - $0 may be a link to maven's home

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/bin/mqbroker.xml
----------------------------------------------------------------------
diff --git a/bin/mqbroker.xml b/bin/mqbroker.xml
index 289da61..d1bc16f 100644
--- a/bin/mqbroker.xml
+++ b/bin/mqbroker.xml
@@ -8,11 +8,11 @@
 
       http://www.apache.org/licenses/LICENSE-2.0
 
-   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.
-   See the License for the specific language governing permissions and
-   limitations under the License.
+  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.
+  See the License for the specific language governing permissions and
+  limitations under the License.
   -->
 
 <java>

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/bin/mqfiltersrv
----------------------------------------------------------------------
diff --git a/bin/mqfiltersrv b/bin/mqfiltersrv
index ff83a7a..2fd0cbe 100644
--- a/bin/mqfiltersrv
+++ b/bin/mqfiltersrv
@@ -9,11 +9,11 @@
 #
 #     http://www.apache.org/licenses/LICENSE-2.0
 #
-#  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.
-#  See the License for the specific language governing permissions and
-#  limitations under the License.
+# 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.
+# See the License for the specific language governing permissions and
+# limitations under the License.
 
 if [ -z "$ROCKETMQ_HOME" ] ; then
   ## resolve links - $0 may be a link to maven's home

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/bin/mqfiltersrv.xml
----------------------------------------------------------------------
diff --git a/bin/mqfiltersrv.xml b/bin/mqfiltersrv.xml
index 105ea26..8fdea39 100644
--- a/bin/mqfiltersrv.xml
+++ b/bin/mqfiltersrv.xml
@@ -8,11 +8,11 @@
 
       http://www.apache.org/licenses/LICENSE-2.0
 
-   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.
-   See the License for the specific language governing permissions and
-   limitations under the License.
+  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.
+  See the License for the specific language governing permissions and
+  limitations under the License.
   -->
 
 <java>

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/bin/mqnamesrv
----------------------------------------------------------------------
diff --git a/bin/mqnamesrv b/bin/mqnamesrv
index 94ec8f2..c1e70bd 100644
--- a/bin/mqnamesrv
+++ b/bin/mqnamesrv
@@ -9,11 +9,11 @@
 #
 #     http://www.apache.org/licenses/LICENSE-2.0
 #
-#  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.
-#  See the License for the specific language governing permissions and
-#  limitations under the License.
+# 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.
+# See the License for the specific language governing permissions and
+# limitations under the License.
 
 if [ -z "$ROCKETMQ_HOME" ] ; then
   ## resolve links - $0 may be a link to maven's home

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/bin/mqnamesrv.xml
----------------------------------------------------------------------
diff --git a/bin/mqnamesrv.xml b/bin/mqnamesrv.xml
index 8ea3102..dc5736a 100644
--- a/bin/mqnamesrv.xml
+++ b/bin/mqnamesrv.xml
@@ -8,11 +8,11 @@
 
       http://www.apache.org/licenses/LICENSE-2.0
 
-   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.
-   See the License for the specific language governing permissions and
-   limitations under the License.
+  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.
+  See the License for the specific language governing permissions and
+  limitations under the License.
   -->
 
 <java>

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/bin/mqshutdown
----------------------------------------------------------------------
diff --git a/bin/mqshutdown b/bin/mqshutdown
index 5f1a174..d2d51fc 100644
--- a/bin/mqshutdown
+++ b/bin/mqshutdown
@@ -9,11 +9,11 @@
 #
 #     http://www.apache.org/licenses/LICENSE-2.0
 #
-#  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.
-#  See the License for the specific language governing permissions and
-#  limitations under the License.
+# 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.
+# See the License for the specific language governing permissions and
+# limitations under the License.
 
 case $1 in
     broker)

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/bin/os.sh
----------------------------------------------------------------------
diff --git a/bin/os.sh b/bin/os.sh
index 17911d4..f620158 100755
--- a/bin/os.sh
+++ b/bin/os.sh
@@ -9,15 +9,11 @@
 #
 #     http://www.apache.org/licenses/LICENSE-2.0
 #
-#  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.
-#  See the License for the specific language governing permissions and
-#  limitations under the License.
-
-#
-# Execute Only Once
-#
+# 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.
+# See the License for the specific language governing permissions and
+# limitations under the License.
 
 export PATH=$PATH:/sbin
 

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/bin/play.sh
----------------------------------------------------------------------
diff --git a/bin/play.sh b/bin/play.sh
index 4abb648..359d18d 100755
--- a/bin/play.sh
+++ b/bin/play.sh
@@ -9,11 +9,11 @@
 #
 #     http://www.apache.org/licenses/LICENSE-2.0
 #
-#  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.
-#  See the License for the specific language governing permissions and
-#  limitations under the License.
+# 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.
+# See the License for the specific language governing permissions and
+# limitations under the License.
 
 #
 # Name Server

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/bin/runbroker.sh
----------------------------------------------------------------------
diff --git a/bin/runbroker.sh b/bin/runbroker.sh
index 08d97ad..3405d39 100755
--- a/bin/runbroker.sh
+++ b/bin/runbroker.sh
@@ -9,11 +9,11 @@
 #
 #     http://www.apache.org/licenses/LICENSE-2.0
 #
-#  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.
-#  See the License for the specific language governing permissions and
-#  limitations under the License.
+# 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.
+# See the License for the specific language governing permissions and
+# limitations under the License.
 
 #===========================================================================================
 # Java Environment Setting

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/bin/runserver.sh
----------------------------------------------------------------------
diff --git a/bin/runserver.sh b/bin/runserver.sh
index a0d4f0c..e85991c 100755
--- a/bin/runserver.sh
+++ b/bin/runserver.sh
@@ -9,11 +9,11 @@
 #
 #     http://www.apache.org/licenses/LICENSE-2.0
 #
-#  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.
-#  See the License for the specific language governing permissions and
-#  limitations under the License.
+# 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.
+# See the License for the specific language governing permissions and
+# limitations under the License.
 
 #===========================================================================================
 # Java Environment Setting

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/bin/setcache.sh
----------------------------------------------------------------------
diff --git a/bin/setcache.sh b/bin/setcache.sh
index 5c72fd1..27633f3 100755
--- a/bin/setcache.sh
+++ b/bin/setcache.sh
@@ -9,11 +9,11 @@
 #
 #     http://www.apache.org/licenses/LICENSE-2.0
 #
-#  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.
-#  See the License for the specific language governing permissions and
-#  limitations under the License.
+# 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.
+# See the License for the specific language governing permissions and
+# limitations under the License.
 
 export PATH=$PATH:/sbin
 

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/bin/startfsrv.sh
----------------------------------------------------------------------
diff --git a/bin/startfsrv.sh b/bin/startfsrv.sh
index 7ce7d71..f7ba188 100755
--- a/bin/startfsrv.sh
+++ b/bin/startfsrv.sh
@@ -9,11 +9,11 @@
 #
 #     http://www.apache.org/licenses/LICENSE-2.0
 #
-#  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.
-#  See the License for the specific language governing permissions and
-#  limitations under the License.
+# 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.
+# See the License for the specific language governing permissions and
+# limitations under the License.
 
 if [ -z "$ROCKETMQ_HOME" ] ; then
   ## resolve links - $0 may be a link to maven's home

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/bin/tools.sh
----------------------------------------------------------------------
diff --git a/bin/tools.sh b/bin/tools.sh
index 63e8884..66862ca 100755
--- a/bin/tools.sh
+++ b/bin/tools.sh
@@ -9,11 +9,11 @@
 #
 #     http://www.apache.org/licenses/LICENSE-2.0
 #
-#  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.
-#  See the License for the specific language governing permissions and
-#  limitations under the License.
+# 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.
+# See the License for the specific language governing permissions and
+# limitations under the License.
 
 #===========================================================================================
 # Java Environment Setting

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/broker/pom.xml
----------------------------------------------------------------------
diff --git a/broker/pom.xml b/broker/pom.xml
index 30525e4..fae61c2 100644
--- a/broker/pom.xml
+++ b/broker/pom.xml
@@ -8,11 +8,11 @@
 
       http://www.apache.org/licenses/LICENSE-2.0
 
-   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.
-   See the License for the specific language governing permissions and
-   limitations under the License.
+  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.
+  See the License for the specific language governing permissions and
+  limitations under the License.
   -->
 
 <project xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xmlns="http://maven.apache.org/POM/4.0.0"

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/broker/src/main/java/org/apache/rocketmq/broker/BrokerController.java
----------------------------------------------------------------------
diff --git a/broker/src/main/java/org/apache/rocketmq/broker/BrokerController.java b/broker/src/main/java/org/apache/rocketmq/broker/BrokerController.java
index f2fea43..4fa3e21 100644
--- a/broker/src/main/java/org/apache/rocketmq/broker/BrokerController.java
+++ b/broker/src/main/java/org/apache/rocketmq/broker/BrokerController.java
@@ -1,13 +1,13 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
  * 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>
- * http://www.apache.org/licenses/LICENSE-2.0
- * <p>
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
  * 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.

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/broker/src/main/java/org/apache/rocketmq/broker/BrokerPathConfigHelper.java
----------------------------------------------------------------------
diff --git a/broker/src/main/java/org/apache/rocketmq/broker/BrokerPathConfigHelper.java b/broker/src/main/java/org/apache/rocketmq/broker/BrokerPathConfigHelper.java
index 7a46df3..9a4a9e8 100644
--- a/broker/src/main/java/org/apache/rocketmq/broker/BrokerPathConfigHelper.java
+++ b/broker/src/main/java/org/apache/rocketmq/broker/BrokerPathConfigHelper.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -6,7 +6,7 @@
  * (the "License"); you may not use this file except in compliance with
  * the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *     http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/broker/src/main/java/org/apache/rocketmq/broker/BrokerStartup.java
----------------------------------------------------------------------
diff --git a/broker/src/main/java/org/apache/rocketmq/broker/BrokerStartup.java b/broker/src/main/java/org/apache/rocketmq/broker/BrokerStartup.java
index 4c23eb0..e5d0431 100644
--- a/broker/src/main/java/org/apache/rocketmq/broker/BrokerStartup.java
+++ b/broker/src/main/java/org/apache/rocketmq/broker/BrokerStartup.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -6,7 +6,7 @@
  * (the "License"); you may not use this file except in compliance with
  * the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *     http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/broker/src/main/java/org/apache/rocketmq/broker/client/ClientChannelInfo.java
----------------------------------------------------------------------
diff --git a/broker/src/main/java/org/apache/rocketmq/broker/client/ClientChannelInfo.java b/broker/src/main/java/org/apache/rocketmq/broker/client/ClientChannelInfo.java
index b37fce5..edcba96 100644
--- a/broker/src/main/java/org/apache/rocketmq/broker/client/ClientChannelInfo.java
+++ b/broker/src/main/java/org/apache/rocketmq/broker/client/ClientChannelInfo.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -6,7 +6,7 @@
  * (the "License"); you may not use this file except in compliance with
  * the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *     http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/broker/src/main/java/org/apache/rocketmq/broker/client/ClientHousekeepingService.java
----------------------------------------------------------------------
diff --git a/broker/src/main/java/org/apache/rocketmq/broker/client/ClientHousekeepingService.java b/broker/src/main/java/org/apache/rocketmq/broker/client/ClientHousekeepingService.java
index 5d7c0ea..559dac1 100644
--- a/broker/src/main/java/org/apache/rocketmq/broker/client/ClientHousekeepingService.java
+++ b/broker/src/main/java/org/apache/rocketmq/broker/client/ClientHousekeepingService.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -6,7 +6,7 @@
  * (the "License"); you may not use this file except in compliance with
  * the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *     http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/broker/src/main/java/org/apache/rocketmq/broker/client/ConsumerGroupInfo.java
----------------------------------------------------------------------
diff --git a/broker/src/main/java/org/apache/rocketmq/broker/client/ConsumerGroupInfo.java b/broker/src/main/java/org/apache/rocketmq/broker/client/ConsumerGroupInfo.java
index 2656467..7e9c496 100644
--- a/broker/src/main/java/org/apache/rocketmq/broker/client/ConsumerGroupInfo.java
+++ b/broker/src/main/java/org/apache/rocketmq/broker/client/ConsumerGroupInfo.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -6,7 +6,7 @@
  * (the "License"); you may not use this file except in compliance with
  * the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *     http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/broker/src/main/java/org/apache/rocketmq/broker/client/ConsumerIdsChangeListener.java
----------------------------------------------------------------------
diff --git a/broker/src/main/java/org/apache/rocketmq/broker/client/ConsumerIdsChangeListener.java b/broker/src/main/java/org/apache/rocketmq/broker/client/ConsumerIdsChangeListener.java
index fbec010..07d28dc 100644
--- a/broker/src/main/java/org/apache/rocketmq/broker/client/ConsumerIdsChangeListener.java
+++ b/broker/src/main/java/org/apache/rocketmq/broker/client/ConsumerIdsChangeListener.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -6,7 +6,7 @@
  * (the "License"); you may not use this file except in compliance with
  * the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *     http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/broker/src/main/java/org/apache/rocketmq/broker/client/ConsumerManager.java
----------------------------------------------------------------------
diff --git a/broker/src/main/java/org/apache/rocketmq/broker/client/ConsumerManager.java b/broker/src/main/java/org/apache/rocketmq/broker/client/ConsumerManager.java
index fd4fb88..10d43b3 100644
--- a/broker/src/main/java/org/apache/rocketmq/broker/client/ConsumerManager.java
+++ b/broker/src/main/java/org/apache/rocketmq/broker/client/ConsumerManager.java
@@ -1,13 +1,13 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
  * 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>
- * http://www.apache.org/licenses/LICENSE-2.0
- * <p>
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
  * 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.

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/broker/src/main/java/org/apache/rocketmq/broker/client/DefaultConsumerIdsChangeListener.java
----------------------------------------------------------------------
diff --git a/broker/src/main/java/org/apache/rocketmq/broker/client/DefaultConsumerIdsChangeListener.java b/broker/src/main/java/org/apache/rocketmq/broker/client/DefaultConsumerIdsChangeListener.java
index 93f73b8..a1b2d8a 100644
--- a/broker/src/main/java/org/apache/rocketmq/broker/client/DefaultConsumerIdsChangeListener.java
+++ b/broker/src/main/java/org/apache/rocketmq/broker/client/DefaultConsumerIdsChangeListener.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -6,7 +6,7 @@
  * (the "License"); you may not use this file except in compliance with
  * the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *     http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/broker/src/main/java/org/apache/rocketmq/broker/client/ProducerManager.java
----------------------------------------------------------------------
diff --git a/broker/src/main/java/org/apache/rocketmq/broker/client/ProducerManager.java b/broker/src/main/java/org/apache/rocketmq/broker/client/ProducerManager.java
index 3047faf..b4dc305 100644
--- a/broker/src/main/java/org/apache/rocketmq/broker/client/ProducerManager.java
+++ b/broker/src/main/java/org/apache/rocketmq/broker/client/ProducerManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -6,7 +6,7 @@
  * (the "License"); you may not use this file except in compliance with
  * the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *     http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/broker/src/main/java/org/apache/rocketmq/broker/client/net/Broker2Client.java
----------------------------------------------------------------------
diff --git a/broker/src/main/java/org/apache/rocketmq/broker/client/net/Broker2Client.java b/broker/src/main/java/org/apache/rocketmq/broker/client/net/Broker2Client.java
index f6d7955..1fdf3db 100644
--- a/broker/src/main/java/org/apache/rocketmq/broker/client/net/Broker2Client.java
+++ b/broker/src/main/java/org/apache/rocketmq/broker/client/net/Broker2Client.java
@@ -1,13 +1,13 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
  * 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>
- * http://www.apache.org/licenses/LICENSE-2.0
- * <p>
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
  * 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.

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/broker/src/main/java/org/apache/rocketmq/broker/client/rebalance/RebalanceLockManager.java
----------------------------------------------------------------------
diff --git a/broker/src/main/java/org/apache/rocketmq/broker/client/rebalance/RebalanceLockManager.java b/broker/src/main/java/org/apache/rocketmq/broker/client/rebalance/RebalanceLockManager.java
index 88c044a..426fcf2 100644
--- a/broker/src/main/java/org/apache/rocketmq/broker/client/rebalance/RebalanceLockManager.java
+++ b/broker/src/main/java/org/apache/rocketmq/broker/client/rebalance/RebalanceLockManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -6,7 +6,7 @@
  * (the "License"); you may not use this file except in compliance with
  * the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *     http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/broker/src/main/java/org/apache/rocketmq/broker/filtersrv/FilterServerManager.java
----------------------------------------------------------------------
diff --git a/broker/src/main/java/org/apache/rocketmq/broker/filtersrv/FilterServerManager.java b/broker/src/main/java/org/apache/rocketmq/broker/filtersrv/FilterServerManager.java
index c1b67ae..35b6dc4 100644
--- a/broker/src/main/java/org/apache/rocketmq/broker/filtersrv/FilterServerManager.java
+++ b/broker/src/main/java/org/apache/rocketmq/broker/filtersrv/FilterServerManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -6,7 +6,7 @@
  * (the "License"); you may not use this file except in compliance with
  * the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *     http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/broker/src/main/java/org/apache/rocketmq/broker/filtersrv/FilterServerUtil.java
----------------------------------------------------------------------
diff --git a/broker/src/main/java/org/apache/rocketmq/broker/filtersrv/FilterServerUtil.java b/broker/src/main/java/org/apache/rocketmq/broker/filtersrv/FilterServerUtil.java
index 9edfbe4..818b238 100644
--- a/broker/src/main/java/org/apache/rocketmq/broker/filtersrv/FilterServerUtil.java
+++ b/broker/src/main/java/org/apache/rocketmq/broker/filtersrv/FilterServerUtil.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -6,7 +6,7 @@
  * (the "License"); you may not use this file except in compliance with
  * the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *     http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/broker/src/main/java/org/apache/rocketmq/broker/latency/BrokerFastFailure.java
----------------------------------------------------------------------
diff --git a/broker/src/main/java/org/apache/rocketmq/broker/latency/BrokerFastFailure.java b/broker/src/main/java/org/apache/rocketmq/broker/latency/BrokerFastFailure.java
index f885b71..c004d1b 100644
--- a/broker/src/main/java/org/apache/rocketmq/broker/latency/BrokerFastFailure.java
+++ b/broker/src/main/java/org/apache/rocketmq/broker/latency/BrokerFastFailure.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -6,7 +6,7 @@
  * (the "License"); you may not use this file except in compliance with
  * the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *     http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/broker/src/main/java/org/apache/rocketmq/broker/latency/BrokerFixedThreadPoolExecutor.java
----------------------------------------------------------------------
diff --git a/broker/src/main/java/org/apache/rocketmq/broker/latency/BrokerFixedThreadPoolExecutor.java b/broker/src/main/java/org/apache/rocketmq/broker/latency/BrokerFixedThreadPoolExecutor.java
index 5a4ad2d..238fe1c 100644
--- a/broker/src/main/java/org/apache/rocketmq/broker/latency/BrokerFixedThreadPoolExecutor.java
+++ b/broker/src/main/java/org/apache/rocketmq/broker/latency/BrokerFixedThreadPoolExecutor.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -6,7 +6,7 @@
  * (the "License"); you may not use this file except in compliance with
  * the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *     http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,

http://git-wip-us.apache.org/repos/asf/incubator-rocketmq/blob/f9d90201/broker/src/main/java/org/apache/rocketmq/broker/latency/FutureTaskExt.java
----------------------------------------------------------------------
diff --git a/broker/src/main/java/org/apache/rocketmq/broker/latency/FutureTaskExt.java b/broker/src/main/java/org/apache/rocketmq/broker/latency/FutureTaskExt.java
index 9454a57..f132efa 100644
--- a/broker/src/main/java/org/apache/rocketmq/broker/latency/FutureTaskExt.java
+++ b/broker/src/main/java/org/apache/rocketmq/broker/latency/FutureTaskExt.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
@@ -6,7 +6,7 @@
  * (the "License"); you may not use this file except in compliance with
  * the License.  You may obtain a copy of the License at
  *
- * http://www.apache.org/licenses/LICENSE-2.0
+ *     http://www.apache.org/licenses/LICENSE-2.0
  *
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,