Examples of MessageId


Examples of backtype.storm.tuple.MessageId

  long root_id = MessageId.generateId();
  Integer askers=StormUtils.parseInt(storm_conf.get(Config.TOPOLOGY_ACKERS));
  Boolean isroot = (message_id != null)&&(askers > 0);

  for (Integer t : out_tasks) {
      MessageId msgid;
      if (isroot) {
    msgid = MessageId.makeRootId(root_id, t);
      } else {
    msgid = MessageId.makeUnanchored();
      }
View Full Code Here

Examples of backtype.storm.tuple.MessageId

      for (Long root_id : a.getMessageId().getAnchorsToIds().keySet()) {
          TasksCommon.put_xor(anchors_to_ids, root_id, edge_id);
      }
        }
    }
    MessageId msgid=MessageId.makeId(anchors_to_ids);
    workerTransfer.transfer(t,new Tuple(topologyContext, values, task_id,out_stream_id, msgid));

      }
      return StormUtils.mk_list(out_tasks);
  } catch (Exception e) {
View Full Code Here

Examples of backtype.storm.tuple.MessageId

                DataInputStream in = new DataInputStream(bin);
                int taskId = WritableUtils.readVInt(in);
                int streamId = WritableUtils.readVInt(in);
                String componentName = _context.getComponentId(taskId);
                String streamName = _ids.getStreamName(componentName, streamId);
                MessageId id = MessageId.deserialize(in);
                List<Object> values = _kryo.deserializeFrom(bin);
                return new Tuple(_context, values, taskId, streamName, id);
            } catch(IOException e) {
                throw new RuntimeException(e);
            }
View Full Code Here

Examples of com.adobe.epubcheck.messages.MessageId

  void searchInsideValue(CSSStyleAttributeHandler.StyleAttribute entry, SearchDictionary tds, String file)
  {
    for (int s = 0; s < tds.getDictEntries().size(); s++)
    {
      TextSearchDictionaryEntry de = tds.getDictEntries().get(s);
      MessageId messageCode = de.getErrorCode();
      Pattern p = de.getPattern();

      Matcher matcher = p.matcher(entry.getValue());
      int position = 0;
      while (matcher.find(position))
View Full Code Here

Examples of com.alibaba.rocketmq.common.message.MessageId

                    .decodeCommandCustomHeader(ConsumeMessageDirectlyResultRequestHeader.class);

        request.getExtFields().put("brokerName", this.brokerController.getBrokerConfig().getBrokerName());
        SelectMapedBufferResult selectMapedBufferResult = null;
        try {
            MessageId messageId = MessageDecoder.decodeMessageId(requestHeader.getMsgId());
            selectMapedBufferResult =
                    this.brokerController.getMessageStore().selectOneMessageByOffset(messageId.getOffset());

            byte[] body = new byte[selectMapedBufferResult.getSize()];
            selectMapedBufferResult.getByteBuffer().get(body);
            request.setBody(body);
        }
View Full Code Here

Examples of com.dianping.cat.message.internal.MessageId

    Transaction t = cat.newTransaction("BucketService", getClass().getSimpleName());

    t.setStatus(Message.SUCCESS);

    try {
      MessageId id = MessageId.parse(messageId);
      final String path = m_pathBuilder.getPath(new Date(id.getTimestamp()), "");
      final StringBuilder sb = new StringBuilder();
      FileSystem fs = m_manager.getFileSystem("dump", sb);

      sb.append('/').append(path);

      final String key = id.getDomain() + '-' + id.getIpAddress();
      final String str = sb.toString();
      final Path basePath = new Path(str);
      final List<String> paths = new ArrayList<String>();

      fs.listStatus(basePath, new PathFilter() {
View Full Code Here

Examples of io.fabric8.gateway.handlers.detecting.protocol.openwire.command.MessageId

   
    /**
     * @return a new object instance
     */
    public DataStructure createObject() {
        return new MessageId();
    }
View Full Code Here

Examples of jifx.commons.messages.MessageID

  @Override
  public void messageReceived(IoSession session, Object message) {
    try {
      if (message != null) {
        IMessage im = (IMessage) message;
        MessageID msgId = new MessageID(messageIDInfo, im);
        registerSession(msgId, session);
        if (logger.isDebugEnabled())
          logger.debug(session.getAttachment()+"|Mensaje recibido: |"+message);
        server.messageProcessTM(im);
      }
View Full Code Here

Examples of net.tomp2p.message.MessageID

            final ConnectionBean connectionBean, final ConnectionConfiguration configuration) {
        this.peerBean = peerBean;
        this.connectionBean = connectionBean;
        this.futureResponse = futureResponse;
        this.message = futureResponse.request();
        this.sendMessageID = new MessageID(message);
        this.idleTCPSeconds = configuration.idleTCPSeconds();
        this.idleUDPSeconds = configuration.idleUDPSeconds();
        this.connectionTimeoutTCPMillis = configuration.connectionTimeoutTCPMillis();
    }
View Full Code Here

Examples of org.apache.activemq.apollo.openwire.command.MessageId

    /**
     * @return a new object instance
     */
    public DataStructure createObject() {
        return new MessageId();
    }
View Full Code Here
TOP
Copyright © 2018 www.massapi.com. All rights reserved.
All source code are property of their respective owners. Java is a trademark of Sun Microsystems, Inc and owned by ORACLE Inc. Contact coftware#gmail.com.