activeMO学习笔记一:开始自己的第一个mq

因为项目的需要,在构思系统的架构设计上,想到了ActiveMQ.只所以选择它。开始了学习。
一、首先做了一点小功课。
1、大致了解了JMS的原理的核心API.
2、知道了这是JMS的一个实现。在apache上可以免费下载使用。还不赶快下一个去?

二、运行并观察了官方例子
1、我先在activeMQ的解压目录的bin下执行了:

activemq

启动了这的borker.

2、在一个新的cmd窗口中,我在activeMQ的解压目录的example目录下执行了:

ant producer

可以看到输出了N多发送的消息文字。

3、在另一个新的cmd窗口中,我在activeMQ的解压目录的example目录下执行了:

ant consumer

可以看到输出了N多接收到的消息文字。
到这里,大概可以知道了mq的基本运行框架。即,由一个broker作为中间代理。接收了传输消息。两端分别是消息的供应方"Producer",负责将消息发送到"Broker",和消息的消费方"Consumer",负责取出这些消息。

三、开始构建自己的第一个MQ
1、新建一个java工程,暂叫Project1吧,由它承担"Broker"和“Producer"的角色。当然也可以完全分开。
(别忘了将activeMQ的jar包放进来,要不都是白搭)
2、在Project1中创建一自己的"Broker",这里用了一种代码实现的居说叫“EmbeddedBroker" 的Broker.还没搞明白另外一种borker怎么弄,就先从简单的开始吧

import org.apache.activemq.broker.BrokerService;

/**
* This example demonstrates how to run an embedded broker inside your Java code
*
*
*/
public final class EmbeddedBroker {

private EmbeddedBroker() {
}

public static void main(String[] args) throws Exception {
BrokerService broker = new BrokerService();
broker.setUseJmx(true);
broker.addConnector("tcp://localhost:61616");
broker.start();

// now lets wait forever to avoid the JVM terminating immediately
Object lock = new Object();
synchronized (lock) {
lock.wait();
}
}
}

代码基本可以从例子中copy过来。

3、创建producer.
基本可以将官方例子中的ProducerTool.java稍微调整一下即可。

package test.producer;
/**
* 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
*
* 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.
*/
import java.util.Arrays;
import java.util.ArrayList;
import java.util.Date;
import java.util.Iterator;

import javax.jms.Connection;
import javax.jms.DeliveryMode;
import javax.jms.Destination;
import javax.jms.MessageProducer;
import javax.jms.Session;
import javax.jms.TextMessage;

import org.apache.activemq.ActiveMQConnection;
import org.apache.activemq.ActiveMQConnectionFactory;
import org.apache.activemq.util.IndentPrinter;

/**
* A simple tool for publishing messages
*
*
*/
public class ProducerTool extends Thread {

private Destination destination;
private int messageCount = 10;
private long sleepTime;
private boolean verbose = true;
private int messageSize = 255;
private static int parallelThreads = 1;
private long timeToLive;
private String user = ActiveMQConnection.DEFAULT_USER;
private String password = ActiveMQConnection.DEFAULT_PASSWORD;
private String url = ActiveMQConnection.DEFAULT_BROKER_URL;
private String subject = "MyBroker";
private boolean topic;
private boolean transacted;
private boolean persistent;
private static Object lockResults = new Object();

public static void main(String[] args) {
ArrayList<ProducerTool> threads = new ArrayList();
ProducerTool producerTool = new ProducerTool();

producerTool.showParameters();
for (int threadCount = 1; threadCount <= parallelThreads; threadCount++) {
producerTool = new ProducerTool();
//CommandLineSupport.setOptions(producerTool, args);
producerTool.start();
threads.add(producerTool);
}

while (true) {
Iterator<ProducerTool> itr = threads.iterator();
int running = 0;
while (itr.hasNext()) {
ProducerTool thread = itr.next();
if (thread.isAlive()) {
running++;
}
}
if (running <= 0) {
System.out.println("All threads completed their work");
break;
}
try {
Thread.sleep(1000);
} catch (Exception e) {
}
}
}

public void showParameters() {
System.out.println("Connecting to URL: " + url);
System.out.println("Publishing a Message with size " + messageSize + " to " + (topic ? "topic" : "queue") + ": " + subject);
System.out.println("Using " + (persistent ? "persistent" : "non-persistent") + " messages");
System.out.println("Sleeping between publish " + sleepTime + " ms");
System.out.println("Running " + parallelThreads + " parallel threads");

if (timeToLive != 0) {
System.out.println("Messages time to live " + timeToLive + " ms");
}
}

public void run() {
Connection connection = null;
try {
// Create the connection.
ActiveMQConnectionFactory connectionFactory = new ActiveMQConnectionFactory(user, password, url);
connection = connectionFactory.createConnection();
connection.start();

// Create the session
Session session = connection.createSession(transacted, Session.AUTO_ACKNOWLEDGE);
if (topic) {
destination = session.createTopic(subject);
} else {
destination = session.createQueue(subject);
}

// Create the producer.
MessageProducer producer = session.createProducer(destination);
if (persistent) {
producer.setDeliveryMode(DeliveryMode.PERSISTENT);
} else {
producer.setDeliveryMode(DeliveryMode.NON_PERSISTENT);
}
if (timeToLive != 0) {
producer.setTimeToLive(timeToLive);
}

// Start sending messages
sendLoop(session, producer);

System.out.println("[" + this.getName() + "] Done.");

synchronized (lockResults) {
ActiveMQConnection c = (ActiveMQConnection) connection;
System.out.println("[" + this.getName() + "] Results:\n");
c.getConnectionStats().dump(new IndentPrinter());
}

} catch (Exception e) {
System.out.println("[" + this.getName() + "] Caught: " + e);
e.printStackTrace();
} finally {
try {
connection.close();
} catch (Throwable ignore) {
}
}
}

protected void sendLoop(Session session, MessageProducer producer) throws Exception {

/*for (int i = 0; i < messageCount || messageCount == 0; i++) {

TextMessage message = session.createTextMessage(createMessageText(i));

if (verbose) {
String msg = message.getText();
if (msg.length() > 50) {
msg = msg.substring(0, 50) + "...";
}
System.out.println("[" + this.getName() + "] Sending message: '" + msg + "'");
}

producer.send(message);

if (transacted) {
System.out.println("[" + this.getName() + "] Committing " + messageCount + " messages");
session.commit();
}
Thread.sleep(sleepTime);
}*/
TextMessage message = session.createTextMessage("Hello World.");
producer.send(message);
}

private String createMessageText(int index) {
StringBuffer buffer = new StringBuffer(messageSize);
buffer.append("Message: " + index + " sent at: " + new Date());
if (buffer.length() > messageSize) {
return buffer.substring(0, messageSize);
}
for (int i = buffer.length(); i < messageSize; i++) {
buffer.append(' ');
}
return buffer.toString();
}

public void setPersistent(boolean durable) {
this.persistent = durable;
}

public void setMessageCount(int messageCount) {
this.messageCount = messageCount;
}

public void setMessageSize(int messageSize) {
this.messageSize = messageSize;
}

public void setPassword(String pwd) {
this.password = pwd;
}

public void setSleepTime(long sleepTime) {
this.sleepTime = sleepTime;
}

public void setSubject(String subject) {
this.subject = subject;
}

public void setTimeToLive(long timeToLive) {
this.timeToLive = timeToLive;
}

public void setParallelThreads(int parallelThreads) {
if (parallelThreads < 1) {
parallelThreads = 1;
}
this.parallelThreads = parallelThreads;
}

public void setTopic(boolean topic) {
this.topic = topic;
}

public void setQueue(boolean queue) {
this.topic = !queue;
}

public void setTransacted(boolean transacted) {
this.transacted = transacted;
}

public void setUrl(String url) {
this.url = url;
}

public void setUser(String user) {
this.user = user;
}

public void setVerbose(boolean verbose) {
this.verbose = verbose;
}
}



4、创建consumer。
这里我选择另建一个java工程(还是别忘jar包啊)。并在其中创建consumer

package test.consumer;
/**
* 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
*
* 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.
*/

import java.io.IOException;
import java.util.Arrays;
import java.util.ArrayList;
import java.util.Iterator;

import javax.jms.Connection;
import javax.jms.DeliveryMode;
import javax.jms.Destination;
import javax.jms.ExceptionListener;
import javax.jms.JMSException;
import javax.jms.Message;
import javax.jms.MessageConsumer;
import javax.jms.MessageListener;
import javax.jms.MessageProducer;
import javax.jms.Session;
import javax.jms.TextMessage;
import javax.jms.Topic;

import org.apache.activemq.ActiveMQConnection;
import org.apache.activemq.ActiveMQConnectionFactory;

/**
* A simple tool for consuming messages
*
*
*/
public class ConsumerTool extends Thread implements MessageListener, ExceptionListener {

private boolean running;

private Session session;
private Destination destination;
private MessageProducer replyProducer;

private boolean pauseBeforeShutdown = false;
private boolean verbose = true;
private int maxiumMessages;
private static int parallelThreads = 1;
private String subject = "MyBroker";
private boolean topic;
private String user = ActiveMQConnection.DEFAULT_USER;
private String password = ActiveMQConnection.DEFAULT_PASSWORD;
private String url = ActiveMQConnection.DEFAULT_BROKER_URL;
private boolean transacted;
private boolean durable;
private String clientId;
private int ackMode = Session.AUTO_ACKNOWLEDGE;
private String consumerName = "James";
private long sleepTime;
private long receiveTimeOut;
private long batch = 10; // Default batch size for CLIENT_ACKNOWLEDGEMENT or SESSION_TRANSACTED
private long messagesReceived = 0;

public static void main(String[] args) {
ArrayList<ConsumerTool> threads = new ArrayList();
ConsumerTool consumerTool = new ConsumerTool();
consumerTool.showParameters();
for (int threadCount = 1; threadCount <= parallelThreads; threadCount++) {
consumerTool = new ConsumerTool();
//CommandLineSupport.setOptions(consumerTool, args);
consumerTool.start();
threads.add(consumerTool);
}

while (true) {
Iterator<ConsumerTool> itr = threads.iterator();
int running = 0;
while (itr.hasNext()) {
ConsumerTool thread = itr.next();
if (thread.isAlive()) {
running++;
}
}

if (running <= 0) {
System.out.println("All threads completed their work");
break;
}

try {
Thread.sleep(1000);
} catch (Exception e) {
}
}
Iterator<ConsumerTool> itr = threads.iterator();
while (itr.hasNext()) {
ConsumerTool thread = itr.next();
}
}

public void showParameters() {
System.out.println("Connecting to URL: " + url);
System.out.println("Consuming " + (topic ? "topic" : "queue") + ": " + subject);
System.out.println("Using a " + (durable ? "durable" : "non-durable") + " subscription");
System.out.println("Running " + parallelThreads + " parallel threads");
}

public void run() {
try {
running = true;

ActiveMQConnectionFactory connectionFactory = new ActiveMQConnectionFactory(user, password, url);
Connection connection = connectionFactory.createConnection();
if (durable && clientId != null && clientId.length() > 0 && !"null".equals(clientId)) {
connection.setClientID(clientId);
}
connection.setExceptionListener(this);
connection.start();

session = connection.createSession(transacted, ackMode);
if (topic) {
destination = session.createTopic(subject);
} else {
destination = session.createQueue(subject);
}

replyProducer = session.createProducer(null);
replyProducer.setDeliveryMode(DeliveryMode.NON_PERSISTENT);

MessageConsumer consumer = null;
if (durable && topic) {
consumer = session.createDurableSubscriber((Topic) destination, consumerName);
} else {
consumer = session.createConsumer(destination);
}

if (maxiumMessages > 0) {
consumeMessagesAndClose(connection, session, consumer);
} else {
if (receiveTimeOut == 0) {
consumer.setMessageListener(this);
} else {
consumeMessagesAndClose(connection, session, consumer, receiveTimeOut);
}
}

} catch (Exception e) {
System.out.println("[" + this.getName() + "] Caught: " + e);
e.printStackTrace();
}
}

public void onMessage(Message message) {

messagesReceived++;

try {

if (message instanceof TextMessage) {
TextMessage txtMsg = (TextMessage) message;
if (verbose) {

String msg = txtMsg.getText();
int length = msg.length();
if (length > 50) {
msg = msg.substring(0, 50) + "...";
}
System.out.println("[" + this.getName() + "] Received: '" + msg + "' (length " + length + ")");
}
} else {
if (verbose) {
System.out.println("[" + this.getName() + "] Received: '" + message + "'");
}
}

if (message.getJMSReplyTo() != null) {
replyProducer.send(message.getJMSReplyTo(), session.createTextMessage("Reply: " + message.getJMSMessageID()));
}

if (transacted) {
if ((messagesReceived % batch) == 0) {
System.out.println("Commiting transaction for last " + batch + " messages; messages so far = " + messagesReceived);
session.commit();
}
} else if (ackMode == Session.CLIENT_ACKNOWLEDGE) {
if ((messagesReceived % batch) == 0) {
System.out.println("Acknowledging last " + batch + " messages; messages so far = " + messagesReceived);
message.acknowledge();
}
}

} catch (JMSException e) {
System.out.println("[" + this.getName() + "] Caught: " + e);
e.printStackTrace();
} finally {
if (sleepTime > 0) {
try {
Thread.sleep(sleepTime);
} catch (InterruptedException e) {
}
}
}
}

public synchronized void onException(JMSException ex) {
System.out.println("[" + this.getName() + "] JMS Exception occured. Shutting down client.");
running = false;
}

synchronized boolean isRunning() {
return running;
}

protected void consumeMessagesAndClose(Connection connection, Session session, MessageConsumer consumer) throws JMSException,
IOException {
System.out.println("[" + this.getName() + "] We are about to wait until we consume: " + maxiumMessages
+ " message(s) then we will shutdown");

for (int i = 0; i < maxiumMessages && isRunning();) {
Message message = consumer.receive(1000);
if (message != null) {
i++;
onMessage(message);
}
}
System.out.println("[" + this.getName() + "] Closing connection");
consumer.close();
session.close();
connection.close();
if (pauseBeforeShutdown) {
System.out.println("[" + this.getName() + "] Press return to shut down");
System.in.read();
}
}

protected void consumeMessagesAndClose(Connection connection, Session session, MessageConsumer consumer, long timeout)
throws JMSException, IOException {
System.out.println("[" + this.getName() + "] We will consume messages while they continue to be delivered within: " + timeout
+ " ms, and then we will shutdown");

Message message;
while ((message = consumer.receive(timeout)) != null) {
onMessage(message);
}

System.out.println("[" + this.getName() + "] Closing connection");
consumer.close();
session.close();
connection.close();
if (pauseBeforeShutdown) {
System.out.println("[" + this.getName() + "] Press return to shut down");
System.in.read();
}
}

public void setAckMode(String ackMode) {
if ("CLIENT_ACKNOWLEDGE".equals(ackMode)) {
this.ackMode = Session.CLIENT_ACKNOWLEDGE;
}
if ("AUTO_ACKNOWLEDGE".equals(ackMode)) {
this.ackMode = Session.AUTO_ACKNOWLEDGE;
}
if ("DUPS_OK_ACKNOWLEDGE".equals(ackMode)) {
this.ackMode = Session.DUPS_OK_ACKNOWLEDGE;
}
if ("SESSION_TRANSACTED".equals(ackMode)) {
this.ackMode = Session.SESSION_TRANSACTED;
}
}

public void setClientId(String clientID) {
this.clientId = clientID;
}

public void setConsumerName(String consumerName) {
this.consumerName = consumerName;
}

public void setDurable(boolean durable) {
this.durable = durable;
}

public void setMaxiumMessages(int maxiumMessages) {
this.maxiumMessages = maxiumMessages;
}

public void setPauseBeforeShutdown(boolean pauseBeforeShutdown) {
this.pauseBeforeShutdown = pauseBeforeShutdown;
}

public void setPassword(String pwd) {
this.password = pwd;
}

public void setReceiveTimeOut(long receiveTimeOut) {
this.receiveTimeOut = receiveTimeOut;
}

public void setSleepTime(long sleepTime) {
this.sleepTime = sleepTime;
}

public void setSubject(String subject) {
this.subject = subject;
}

public void setParallelThreads(int parallelThreads) {
if (parallelThreads < 1) {
parallelThreads = 1;
}
this.parallelThreads = parallelThreads;
}

public void setTopic(boolean topic) {
this.topic = topic;
}

public void setQueue(boolean queue) {
this.topic = !queue;
}

public void setTransacted(boolean transacted) {
this.transacted = transacted;
}

public void setUrl(String url) {
this.url = url;
}

public void setUser(String user) {
this.user = user;
}

public void setVerbose(boolean verbose) {
this.verbose = verbose;
}

public void setBatch(long batch) {
this.batch = batch;
}
}



四、试运行自己的mq
1、首先通过“Run As”==>"Java Application", 运行Project1里的broker.启动mq代理
2、通过"Run As"==>"Java Application",运行Project1里的producer.开始往broker中发送信息
3、通过"Run As"==>"Java Application",运行Project2里的consumer.开始从broker里接收消息。
  • 0
    点赞
  • 0
    收藏
    觉得还不错? 一键收藏
  • 0
    评论

“相关推荐”对你有帮助么?

  • 非常没帮助
  • 没帮助
  • 一般
  • 有帮助
  • 非常有帮助
提交
评论
添加红包

请填写红包祝福语或标题

红包个数最小为10个

红包金额最低5元

当前余额3.43前往充值 >
需支付:10.00
成就一亿技术人!
领取后你会自动成为博主和红包主的粉丝 规则
hope_wisdom
发出的红包
实付
使用余额支付
点击重新获取
扫码支付
钱包余额 0

抵扣说明:

1.余额是钱包充值的虚拟货币,按照1:1的比例进行支付金额的抵扣。
2.余额无法直接购买下载,可以购买VIP、付费专栏及课程。

余额充值