Examples of Listener


Examples of net.mygwt.ui.client.event.Listener

    }

    if (animate) {
      FXStyle fx = new FXStyle(getElement());
      fx.duration = animateDuration;
      fx.addListener(Events.EffectComplete, new Listener() {
        public void handleEvent(BaseEvent be) {
          afterHide();
        }
      });
      fx.fadeOut();
View Full Code Here

Examples of net.ser1.stomp.Listener

    try
    {
      client = new Client(serviceStarter.getMessageServer(), serviceStarter.getPort(), serviceStarter.getMessageServerUser(), serviceStarter.getMessageServerPass());

      /* Add a listener to watch for ERROR frames being returned */
      client.addErrorListener(new Listener()
      {
        @Override
        public void message(@SuppressWarnings("rawtypes") Map headers, String body)
        {
          NotificationUtilities.dumpMessageToStdOut(body);
View Full Code Here

Examples of net.sourceforge.ganttproject.roles.RoleManager.Listener

  }

  void fireRolesChanged(RoleSet changedRoleSet) {
    RoleEvent event = new RoleEvent(this, changedRoleSet);
    for (int i=0; i<myListeners.size(); i++) {
      Listener next = (Listener) myListeners.get(i);
      next.rolesChanged(event);
    }
  }
View Full Code Here

Examples of net.sourceforge.ganttproject.task.TaskSelectionManager.Listener

        this.add(jp, BorderLayout.WEST);
        hbar = scrollpane.getHorizontalScrollBar();
        vbar.addAdjustmentListener(new GanttAdjustmentListener());

        mySelectionManager.addSelectionListener(new Listener() {
            public void selectionChanged(List currentSelection) {
            }
      public void userInputConsumerChanged(Object newConsumer) {
                if (treetable.getTable().isEditing()) {
                    treetable.getTable().editingStopped(new ChangeEvent(treetable.getTreeTable()));
View Full Code Here

Examples of net.sourceforge.htmlunit.corejs.javascript.ContextFactory.Listener

                }
            });

            // if no other debugger is installed, install jsDebugger,
            // so as not to interfere with the 'Dim' class.
            getJavaScriptEngine().getContextFactory().addListener(new Listener() {
                public void contextCreated(Context cx) {
                    if (cx.getDebugger() == null)
                        cx.setDebugger(jsDebugger, null);
                }
View Full Code Here

Examples of org.apache.accumulo.master.EventCoordinator.Listener

      zoo.putPersistentData(path, "forced down".getBytes(Constants.UTF8), NodeExistsPolicy.OVERWRITE);
      return null;
    }
   
    // TODO move this to isReady() and drop while loop? - ACCUMULO-1259
    Listener listener = master.getEventCoordinator().getListener();
    master.shutdownTServer(server);
    while (master.onlineTabletServers().contains(server)) {
      TServerConnection connection = master.getConnection(server);
      if (connection != null) {
        try {
          TabletServerStatus status = connection.getTableMap(false);
          if (status.tableMap != null && status.tableMap.isEmpty()) {
            log.info("tablet server hosts no tablets " + server);
            connection.halt(master.getMasterLock());
            log.info("tablet server asked to halt " + server);
            break;
          }
        } catch (TTransportException ex) {
          // expected
        } catch (Exception ex) {
          log.error("Error talking to tablet server " + server + ": " + ex);
        }
      }
      listener.waitForEvents(1000);
    }
   
    return null;
  }
View Full Code Here

Examples of org.apache.accumulo.server.master.EventCoordinator.Listener

      zoo.putPersistentData(path, "forced down".getBytes(Constants.UTF8), NodeExistsPolicy.OVERWRITE);
      return null;
    }
   
    // TODO move this to isReady() and drop while loop? - ACCUMULO-1259
    Listener listener = master.getEventCoordinator().getListener();
    master.shutdownTServer(server);
    while (master.onlineTabletServers().contains(server)) {
      TServerConnection connection = master.getConnection(server);
      if (connection != null) {
        try {
          TabletServerStatus status = connection.getTableMap(false);
          if (status.tableMap != null && status.tableMap.isEmpty()) {
            log.info("tablet server hosts no tablets " + server);
            connection.halt(master.getMasterLock());
            log.info("tablet server asked to halt " + server);
            break;
          }
        } catch (TTransportException ex) {
          // expected
        } catch (Exception ex) {
          log.error("Error talking to tablet server " + server + ": " + ex);
        }
      }
      listener.waitForEvents(1000);
    }
   
    return null;
  }
View Full Code Here

Examples of org.apache.accumulo.server.master.LiveTServerSet.Listener

    Instance instance = opts.getInstance();
    MetaDataTableScanner rootScanner = new MetaDataTableScanner(instance, SecurityConstants.getSystemCredentials(), Constants.METADATA_ROOT_TABLET_KEYSPACE);
    MetaDataTableScanner metaScanner = new MetaDataTableScanner(instance, SecurityConstants.getSystemCredentials(), Constants.NON_ROOT_METADATA_KEYSPACE);
    @SuppressWarnings("unchecked")
    Iterator<TabletLocationState> scanner = (Iterator<TabletLocationState>)new IteratorChain(rootScanner, metaScanner);
    LiveTServerSet tservers = new LiveTServerSet(instance, DefaultConfiguration.getDefaultConfiguration(), new Listener() {
      @Override
      public void update(LiveTServerSet current, Set<TServerInstance> deleted, Set<TServerInstance> added) {
        if (!deleted.isEmpty() && scanning.get())
          log.warn("Tablet servers deleted while scanning: " + deleted);
        if (!added.isEmpty() && scanning.get())
View Full Code Here

Examples of org.apache.axis.client.async.Listener

        if (getAsyncStatus() == ASYNC_RUNNING) {
          // TODO: we need to throw an error
          // We can't have two async operations messing with this
          // single Call object
        }
        Listener listener = (Listener)getProperty(AsyncCall.ASYNC_CALL_LISTENER);
        if (listener == null) {
          listener = new Listener() { // Create default RPC listener
            public void invokeComplete() {
              setAsyncStatus(ASYNC_READY);
            }
            public void onResponse(final MessageContext context)
              throws java.rmi.RemoteException {
View Full Code Here

Examples of org.apache.catalina.tribes.test.channel.TestDataIntegrity.Listener

        super.setUp();
        channel1 = new GroupChannel();
        channel1.addInterceptor(new MessageDispatch15Interceptor());
        channel2 = new GroupChannel();
        channel2.addInterceptor(new MessageDispatch15Interceptor());
        listener1 = new Listener();
        channel2.addChannelListener(listener1);
        channel1.start(GroupChannel.DEFAULT);
        channel2.start(GroupChannel.DEFAULT);
    }
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.