AmqpClient.java 13 KB

123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307
  1. package com.persagy.ztkencryptdecodedata.alibabaiot;
  2. import org.apache.commons.codec.binary.Base64;
  3. import org.apache.qpid.jms.JmsConnection;
  4. import org.apache.qpid.jms.JmsConnectionListener;
  5. import org.apache.qpid.jms.message.JmsInboundMessageDispatch;
  6. import org.slf4j.Logger;
  7. import org.slf4j.LoggerFactory;
  8. import org.springframework.beans.factory.annotation.Value;
  9. import org.springframework.boot.ApplicationArguments;
  10. import org.springframework.boot.ApplicationRunner;
  11. import org.springframework.boot.autoconfigure.condition.ConditionalOnProperty;
  12. import org.springframework.core.annotation.Order;
  13. import org.springframework.scheduling.annotation.Async;
  14. import org.springframework.scheduling.annotation.EnableAsync;
  15. import org.springframework.stereotype.Component;
  16. import javax.crypto.Mac;
  17. import javax.crypto.spec.SecretKeySpec;
  18. import javax.jms.*;
  19. import javax.naming.Context;
  20. import javax.naming.InitialContext;
  21. import java.net.URI;
  22. import java.util.ArrayList;
  23. import java.util.Hashtable;
  24. import java.util.List;
  25. import java.util.concurrent.ExecutorService;
  26. import java.util.concurrent.LinkedBlockingQueue;
  27. import java.util.concurrent.ThreadPoolExecutor;
  28. import java.util.concurrent.TimeUnit;
  29. @Component
  30. @Order(value = 1)
  31. @EnableAsync
  32. @ConditionalOnProperty(prefix = "spring", name="location", havingValue="Cloud")
  33. public class AmqpClient implements ApplicationRunner {
  34. private final static Logger logger = LoggerFactory.getLogger(AmqpClient.class);
  35. @Value("${alibaba.iot.accessKey}")
  36. private String accessKey ;
  37. @Value("${alibaba.iot.accessSecret}")
  38. private String accessSecret ;
  39. @Value("${alibaba.iot.consumerGroupId}")
  40. private String consumerGroupId ;
  41. //iotInstanceId:企业版实例请填写实例ID,公共实例请填空字符串""。
  42. @Value("${alibaba.iot.iotInstanceId}")
  43. private String iotInstanceId ;
  44. //控制台服务端订阅中消费组状态页客户端ID一栏将显示clientId参数。
  45. //建议使用机器UUID、MAC地址、IP等唯一标识等作为clientId。便于您区分识别不同的客户端。
  46. @Value("${alibaba.iot.clientId}")
  47. private String clientId ;
  48. //${YourHost}为接入域名,请参见AMQP客户端接入说明文档。
  49. @Value("${alibaba.iot.host}")
  50. private String host ;
  51. // 指定单个进程启动的连接数
  52. // 单个连接消费速率有限,请参考使用限制,最大64个连接
  53. // 连接数和消费速率及rebalance相关,建议每500QPS增加一个连接
  54. private static int connectionCount = 4;
  55. //业务处理异步线程池,线程池参数可以根据您的业务特点调整,或者您也可以用其他异步方式处理接收到的消息。
  56. private final static ExecutorService executorService = new ThreadPoolExecutor(
  57. Runtime.getRuntime().availableProcessors(),
  58. Runtime.getRuntime().availableProcessors() * 2, 60, TimeUnit.SECONDS,
  59. new LinkedBlockingQueue(50000));
  60. // public static void main(String[] args) throws Exception {
  61. // List<Connection> connections = new ArrayList<>();
  62. //
  63. // //参数说明,请参见AMQP客户端接入说明文档。
  64. // for (int i = 0; i < connectionCount; i++) {
  65. // long timeStamp = System.currentTimeMillis();
  66. // //签名方法:支持hmacmd5、hmacsha1和hmacsha256。
  67. // String signMethod = "hmacsha1";
  68. //
  69. // //userName组装方法,请参见AMQP客户端接入说明文档。
  70. // String userName = clientId +"-" + i + "|authMode=aksign"
  71. // + ",signMethod=" + signMethod
  72. // + ",timestamp=" + timeStamp
  73. // + ",authId=" + accessKey
  74. // + ",iotInstanceId=" + iotInstanceId
  75. // + ",consumerGroupId=" + consumerGroupId
  76. // + "|";
  77. // //计算签名,password组装方法,请参见AMQP客户端接入说明文档。
  78. // String signContent = "authId=" + accessKey + "&timestamp=" + timeStamp;
  79. // String password = doSign(signContent, accessSecret, signMethod);
  80. // //amqp.idleTimeout
  81. // String connectionUrl = "failover:(amqps://" + host + ":5671?amqp.idleTimeout=80000)"
  82. // + "?failover.reconnectDelay=30";
  83. //
  84. // Hashtable<String, String> hashtable = new Hashtable<>();
  85. // hashtable.put("connectionfactory.SBCF", connectionUrl);
  86. // hashtable.put("queue.QUEUE", "default");
  87. // hashtable.put(Context.INITIAL_CONTEXT_FACTORY, "org.apache.qpid.jms.jndi.JmsInitialContextFactory");
  88. // Context context = new InitialContext(hashtable);
  89. // ConnectionFactory cf = (ConnectionFactory)context.lookup("SBCF");
  90. // Destination queue = (Destination)context.lookup("QUEUE");
  91. // // 创建连接。
  92. // Connection connection = cf.createConnection(userName, password);
  93. // connections.add(connection);
  94. //
  95. // ((JmsConnection)connection).addConnectionListener(myJmsConnectionListener);
  96. // // 创建会话。
  97. // // Session.CLIENT_ACKNOWLEDGE: 收到消息后,需要手动调用message.acknowledge()。
  98. // // Session.AUTO_ACKNOWLEDGE: SDK自动ACK(推荐)。
  99. // Session session = connection.createSession(false, Session.AUTO_ACKNOWLEDGE);
  100. //
  101. // connection.start();
  102. // // 创建Receiver连接。
  103. // MessageConsumer consumer = session.createConsumer(queue);
  104. // consumer.setMessageListener(messageListener);
  105. // }
  106. //
  107. // logger.info("amqp demo is started successfully, and will exit after 60s ");
  108. //
  109. // // 结束程序运行
  110. // Thread.sleep(60 * 1000);
  111. // logger.info("run shutdown");
  112. //
  113. // connections.forEach(c-> {
  114. // try {
  115. // c.close();
  116. // } catch (JMSException e) {
  117. // logger.error("failed to close connection", e);
  118. // }
  119. // });
  120. //
  121. // executorService.shutdown();
  122. // if (executorService.awaitTermination(10, TimeUnit.SECONDS)) {
  123. // logger.info("shutdown success");
  124. // } else {
  125. // logger.info("failed to handle messages");
  126. // }
  127. // }
  128. private static MessageListener messageListener = new MessageListener() {
  129. @Override
  130. public void onMessage(final Message message) {
  131. try {
  132. //1.收到消息之后一定要ACK。
  133. // 推荐做法:创建Session选择Session.AUTO_ACKNOWLEDGE,这里会自动ACK。
  134. // 其他做法:创建Session选择Session.CLIENT_ACKNOWLEDGE,这里一定要调message.acknowledge()来ACK。
  135. // message.acknowledge();
  136. //2.建议异步处理收到的消息,确保onMessage函数里没有耗时逻辑。
  137. // 如果业务处理耗时过程过长阻塞住线程,可能会影响SDK收到消息后的正常回调。
  138. executorService.submit(new Runnable() {
  139. @Override
  140. public void run() {
  141. processMessage(message);
  142. }
  143. });
  144. } catch (Exception e) {
  145. logger.error("submit task occurs exception ", e);
  146. }
  147. }
  148. };
  149. /**
  150. * 在这里处理您收到消息后的具体业务逻辑。
  151. */
  152. private static void processMessage(Message message) {
  153. try {
  154. byte[] body = message.getBody(byte[].class);
  155. String content = new String(body);
  156. String topic = message.getStringProperty("topic");
  157. String messageId = message.getStringProperty("messageId");
  158. logger.info("receive message"
  159. + ",\n topic = " + topic
  160. + ",\n messageId = " + messageId
  161. + ",\n content = " + content);
  162. } catch (Exception e) {
  163. logger.error("processMessage occurs error ", e);
  164. }
  165. }
  166. private static JmsConnectionListener myJmsConnectionListener = new JmsConnectionListener() {
  167. /**
  168. * 连接成功建立。
  169. */
  170. @Override
  171. public void onConnectionEstablished(URI remoteURI) {
  172. logger.info("onConnectionEstablished, remoteUri:{}", remoteURI);
  173. }
  174. /**
  175. * 尝试过最大重试次数之后,最终连接失败。
  176. */
  177. @Override
  178. public void onConnectionFailure(Throwable error) {
  179. logger.error("onConnectionFailure, {}", error.getMessage());
  180. }
  181. /**
  182. * 连接中断。
  183. */
  184. @Override
  185. public void onConnectionInterrupted(URI remoteURI) {
  186. logger.info("onConnectionInterrupted, remoteUri:{}", remoteURI);
  187. }
  188. /**
  189. * 连接中断后又自动重连上。
  190. */
  191. @Override
  192. public void onConnectionRestored(URI remoteURI) {
  193. logger.info("onConnectionRestored, remoteUri:{}", remoteURI);
  194. }
  195. @Override
  196. public void onInboundMessage(JmsInboundMessageDispatch envelope) {}
  197. @Override
  198. public void onSessionClosed(Session session, Throwable cause) {}
  199. @Override
  200. public void onConsumerClosed(MessageConsumer consumer, Throwable cause) {}
  201. @Override
  202. public void onProducerClosed(MessageProducer producer, Throwable cause) {}
  203. };
  204. /**
  205. * 计算签名,password组装方法,请参见AMQP客户端接入说明文档。
  206. */
  207. private static String doSign(String toSignString, String secret, String signMethod) throws Exception {
  208. SecretKeySpec signingKey = new SecretKeySpec(secret.getBytes(), signMethod);
  209. Mac mac = Mac.getInstance(signMethod);
  210. mac.init(signingKey);
  211. byte[] rawHmac = mac.doFinal(toSignString.getBytes());
  212. return Base64.encodeBase64String(rawHmac);
  213. }
  214. @Override
  215. @Async
  216. public void run(ApplicationArguments args) throws Exception {
  217. List<Connection> connections = new ArrayList<>();
  218. //参数说明,请参见AMQP客户端接入说明文档。
  219. for (int i = 0; i < connectionCount; i++) {
  220. long timeStamp = System.currentTimeMillis();
  221. //签名方法:支持hmacmd5、hmacsha1和hmacsha256。
  222. String signMethod = "hmacsha1";
  223. //userName组装方法,请参见AMQP客户端接入说明文档。
  224. String userName = clientId +"-" + i + "|authMode=aksign"
  225. + ",signMethod=" + signMethod
  226. + ",timestamp=" + timeStamp
  227. + ",authId=" + accessKey
  228. + ",iotInstanceId=" + iotInstanceId
  229. + ",consumerGroupId=" + consumerGroupId
  230. + "|";
  231. //计算签名,password组装方法,请参见AMQP客户端接入说明文档。
  232. String signContent = "authId=" + accessKey + "&timestamp=" + timeStamp;
  233. String password = doSign(signContent, accessSecret, signMethod);
  234. //amqp.idleTimeout
  235. String connectionUrl = "failover:(amqps://" + host + ":5671?amqp.idleTimeout=80000)"
  236. + "?failover.reconnectDelay=30";
  237. Hashtable<String, String> hashtable = new Hashtable<>();
  238. hashtable.put("connectionfactory.SBCF", connectionUrl);
  239. hashtable.put("queue.QUEUE", "default");
  240. hashtable.put(Context.INITIAL_CONTEXT_FACTORY, "org.apache.qpid.jms.jndi.JmsInitialContextFactory");
  241. Context context = new InitialContext(hashtable);
  242. ConnectionFactory cf = (ConnectionFactory)context.lookup("SBCF");
  243. Destination queue = (Destination)context.lookup("QUEUE");
  244. // 创建连接。
  245. Connection connection = cf.createConnection(userName, password);
  246. connections.add(connection);
  247. ((JmsConnection)connection).addConnectionListener(myJmsConnectionListener);
  248. // 创建会话。
  249. // Session.CLIENT_ACKNOWLEDGE: 收到消息后,需要手动调用message.acknowledge()。
  250. // Session.AUTO_ACKNOWLEDGE: SDK自动ACK(推荐)。
  251. Session session = connection.createSession(false, Session.AUTO_ACKNOWLEDGE);
  252. connection.start();
  253. // 创建Receiver连接。
  254. MessageConsumer consumer = session.createConsumer(queue);
  255. consumer.setMessageListener(messageListener);
  256. }
  257. logger.info("amqp demo is started successfully, and will exit after 60s ");
  258. // 结束程序运行
  259. Thread.sleep(60 * 1000);
  260. logger.info("run shutdown");
  261. connections.forEach(c-> {
  262. try {
  263. c.close();
  264. } catch (JMSException e) {
  265. logger.error("failed to close connection", e);
  266. }
  267. });
  268. executorService.shutdown();
  269. if (executorService.awaitTermination(10, TimeUnit.SECONDS)) {
  270. logger.info("shutdown success");
  271. } else {
  272. logger.info("failed to handle messages");
  273. }
  274. }
  275. }