Examples of Event


Examples of com.atlassian.event.Event

   *            The Bamboo Notification. <br/>
   *            Must not be null and must contain a {@link PlanResultEvent}.
   */
  @Override
  public void sendNotification(Notification notification) {
    Event event = notification.getEvent();
    ResultsSummary result = getResultSummary(event);
    BuildState buildState = result.getBuildState();
    String committersText = createCommittersText(result);
    try {
      client.startInteractiveMode();
View Full Code Here

Examples of com.barchart.feed.api.model.meta.instrument.Event

   */

  @Override
  public DateTime delivery() {

    final Event event = calendar().event(Type.LAST_DELIVERY_DATE);

    if (event == null || event.isNull()) {
      return null;
    }

    return event.date();

  }
View Full Code Here

Examples of com.baulsupp.kolja.log.viewer.event.Event

    for (TextReport<?> r : reports) {
      r.processLine(line);
    }

    if (showEvents) {
      Event event = eventList.readEvent(line);

      if (event != null) {
        for (TextReport<?> r : reports) {
          r.processEvent(event);
        }
View Full Code Here

Examples of com.betfair.cougar.core.api.events.Event

                if (!(message instanceof TextMessage)) {
                    handleInvalidMessageType(message);
                    return;
                }

                Event e = eventUnMarshaller.unmarshallEvent(Arrays.asList(PingEvent.class, eventClass), eventClass, message);
                if (e instanceof PingEvent) {
                    // if pingMonitor not setup then just swallow..
                    if (pingMonitor != null) {
                        pingMonitor.pingReceived((PingEvent) e);
                    }
View Full Code Here

Examples of com.bimbr.clisson.protocol.Event

    /**
     * @see Recorder#event(Set, Set, String)
     */
    public void event(final Set<String> inputMessageIds, final Set<String> outputMessageIds, final String description) {
        event(new Event(sourceId, clock.getTime(), inputMessageIds, outputMessageIds, description));
    }
View Full Code Here

Examples of com.bloomberglp.blpapi.Event

      super.preStart();
    }

    @Override
    protected void dispatch(long maxWaitMilliseconds) {
      Event event = null;
      try {
        event = _sessionProvider.getSession().nextEvent(1000L);
      } catch (InterruptedException e) {
        Thread.interrupted();
      }
      if (event == null) {
        return;
      }
      MessageIterator msgIter = event.messageIterator();
      while (msgIter.hasNext()) {
        Message msg = msgIter.next();
        String bbgUniqueId = msg.topicName();

        if (event.eventType() == Event.EventType.SUBSCRIPTION_DATA) {
          FudgeMsg eventAsFudgeMsg = BloombergDataUtils.parseElement(msg.asElement());
          liveDataReceived(bbgUniqueId, eventAsFudgeMsg);
          // REVIEW 2012-09-19 Andrew -- Why return? Might the event contain multiple messages?
          return;
        }
        s_logger.info("Got event {} {} {}", event.eventType(), bbgUniqueId, msg.asElement());

        if (event.eventType() == Event.EventType.SESSION_STATUS) {
          s_logger.info("SESSION_STATUS event received: {}", msg.messageType());
          if (msg.messageType().toString().equals("SessionTerminated")) {
            disconnect();
            terminate();
          }
View Full Code Here

Examples of com.chenshuo.muduo.example.multiplexer.Event

        if (!queue.isEmpty())
            fail("EventQueue is not empty");

        // step 1
        MockClient client = god.newClient();
        Event ev = queue.take();
        DataEvent de = (DataEvent) ev;
        assertEquals(EventSource.kBackend, de.source);

        Matcher m = god.commandChannel.matcher(de.getString());
        if (!m.matches())
View Full Code Here

Examples of com.cloud.host.Status.Event

        assertTrue(123456789L == aid);
    }

    @Test
    public void testGetEvent() {
        Event e = cac.getEvent();
        assertEquals(Event.AgentConnected, e);
    }
View Full Code Here

Examples of com.cloudera.flume.core.Event

    return Type.getPrimitive(Type.TypeName.TIMESTAMP);
  }

  @Override
  public Object eval(EventWrapper event, Object... args) {
    Event e = event.getEvent();
    return new Timestamp(e.getTimestamp(), e.getNanos());
  }
View Full Code Here

Examples of com.cloudsponge.model.ProgressEvents.Event

      }
    }
  }

  private Event parseEvent(Node eventNode) {
    return new Event(evaluateXPath("event-type", eventNode), evaluateXPath(
        "status", eventNode), evaluateXPath("value", eventNode));
  }
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.