use of org.apache.rocketmq.common.message.Message in project rocketmq-externals by apache.
the class RocketMQSink method process.
@Override
public Status process() throws EventDeliveryException {
Channel channel = getChannel();
Transaction transaction = null;
try {
transaction = channel.getTransaction();
transaction.begin();
/*
batch take
*/
List<Event> events = new ArrayList<>();
long beginTime = System.currentTimeMillis();
while (true) {
Event event = channel.take();
if (event != null) {
events.add(event);
}
if (events.size() == batchSize || System.currentTimeMillis() - beginTime > maxProcessTime) {
break;
}
}
if (events.size() == 0) {
sinkCounter.incrementBatchEmptyCount();
transaction.rollback();
return Status.BACKOFF;
}
/*
async send
*/
CountDownLatch latch = new CountDownLatch(events.size());
AtomicInteger errorNum = new AtomicInteger();
for (Event event : events) {
byte[] body = event.getBody();
Message message = new Message(topic, tag, body);
if (log.isDebugEnabled()) {
log.debug("Processing event,body={}", new String(body, "UTF-8"));
}
producer.send(message, new SendCallBackHandler(message, latch, errorNum));
}
latch.await();
sinkCounter.addToEventDrainAttemptCount(events.size());
if (errorNum.get() > 0) {
log.error("errorNum=" + errorNum + ",transaction will rollback");
transaction.rollback();
return Status.BACKOFF;
} else {
transaction.commit();
sinkCounter.addToEventDrainSuccessCount(events.size());
return Status.READY;
}
} catch (Exception e) {
log.error("Failed to processing event", e);
if (transaction != null) {
try {
transaction.rollback();
} catch (Exception ex) {
log.error("Failed to rollback transaction", ex);
throw new EventDeliveryException("Failed to rollback transaction", ex);
}
}
return Status.BACKOFF;
} finally {
if (transaction != null) {
transaction.close();
}
}
}
use of org.apache.rocketmq.common.message.Message in project rocketmq-externals by apache.
the class RocketMQSourceTest method testEvent.
@Test
public void testEvent() throws EventDeliveryException, MQBrokerException, MQClientException, InterruptedException, UnsupportedEncodingException {
// publish test message
DefaultMQProducer producer = new DefaultMQProducer(producerGroup);
producer.setNamesrvAddr(nameServer);
String sendMsg = "\"Hello Flume\"" + "," + DateFormatUtils.format(new Date(), "yyyy-MM-DD hh:mm:ss");
try {
producer.start();
Message msg = new Message(TOPIC_DEFAULT, tag, sendMsg.getBytes("UTF-8"));
SendResult sendResult = producer.send(msg);
log.info("publish message : {}, sendResult:{}", sendMsg, sendResult);
} catch (Exception e) {
throw new MQClientException("Failed to publish messages", e);
} finally {
producer.shutdown();
}
// start source
Context context = new Context();
context.put(NAME_SERVER_CONFIG, nameServer);
context.put(TAG_CONFIG, tag);
Channel channel = new MemoryChannel();
Configurables.configure(channel, context);
List<Channel> channels = new ArrayList<>();
channels.add(channel);
ChannelSelector channelSelector = new ReplicatingChannelSelector();
channelSelector.setChannels(channels);
ChannelProcessor channelProcessor = new ChannelProcessor(channelSelector);
RocketMQSource source = new RocketMQSource();
source.setChannelProcessor(channelProcessor);
Configurables.configure(source, context);
source.start();
PollableSource.Status status = source.process();
if (status == PollableSource.Status.BACKOFF) {
fail("Error");
}
/*
wait for processQueueTable init
*/
Thread.sleep(1000);
source.stop();
/*
mock flume sink
*/
Transaction transaction = channel.getTransaction();
transaction.begin();
Event event = channel.take();
if (event == null) {
transaction.commit();
fail("Error");
}
byte[] body = event.getBody();
String receiveMsg = new String(body, "UTF-8");
log.info("receive message : {}", receiveMsg);
assertEquals(sendMsg, receiveMsg);
}
use of org.apache.rocketmq.common.message.Message in project rocketmq-externals by apache.
the class RocketMQProducer method send.
/**
* @param event redis event.
* @return true if send success.
* @throws MQClientException MQClientException
* @throws RemotingException RemotingException
* @throws InterruptedException InterruptedException
* @throws MQBrokerException MQBrokerException
*/
public boolean send(Event event) throws MQClientException, RemotingException, InterruptedException, MQBrokerException {
Message msg = new Message(this.topic, toJSONBytes(event, IgnoreNonFieldGetter));
SendResult rs = this.producer.send(msg);
return rs.getSendStatus() == SendStatus.SEND_OK;
}
use of org.apache.rocketmq.common.message.Message in project rocketmq-externals by apache.
the class TestController method list.
@RequestMapping(value = "/runTask.do", method = RequestMethod.GET)
@ResponseBody
public Object list() throws MQClientException, RemotingException, InterruptedException {
DefaultMQPushConsumer consumer = new DefaultMQPushConsumer(testTopic + "Group");
consumer.setNamesrvAddr(rMQConfigure.getNamesrvAddr());
consumer.setConsumeFromWhere(ConsumeFromWhere.CONSUME_FROM_FIRST_OFFSET);
consumer.subscribe(testTopic, "*");
consumer.registerMessageListener(new MessageListenerConcurrently() {
@Override
public ConsumeConcurrentlyStatus consumeMessage(List<MessageExt> msgs, ConsumeConcurrentlyContext context) {
logger.info("receiveMessage msgSize={}", msgs.size());
return ConsumeConcurrentlyStatus.CONSUME_SUCCESS;
}
});
consumer.start();
final DefaultMQProducer producer = new DefaultMQProducer(testTopic + "Group");
producer.setInstanceName(String.valueOf(System.currentTimeMillis()));
producer.setNamesrvAddr(rMQConfigure.getNamesrvAddr());
producer.start();
new Thread(new Runnable() {
@Override
public void run() {
int i = 0;
while (true) {
try {
Message msg = new Message(testTopic, "TagA" + i, "KEYS" + i, ("Hello RocketMQ " + i).getBytes());
Thread.sleep(1000L);
SendResult sendResult = producer.send(msg);
logger.info("sendMessage={}", JsonUtil.obj2String(sendResult));
} catch (Exception e) {
e.printStackTrace();
try {
Thread.sleep(1000);
} catch (Exception ignore) {
}
}
}
}
}).start();
return true;
}
use of org.apache.rocketmq.common.message.Message in project paascloud-master by paascloud.
the class MqMessage method buildMessage.
private static Message buildMessage(String body, String topic, String tag, String key) {
Message message = new Message();
try {
message.setBody(body.getBytes(RemotingHelper.DEFAULT_CHARSET));
} catch (UnsupportedEncodingException e) {
log.error("编码转换,出现异常={}", e.getMessage(), e);
throw new BusinessException(ErrorCodeEnum.TPC100500011);
}
message.setKeys(key);
message.setTopic(topic);
message.setTags(tag);
return message;
}
Aggregations