Examples of Dispatcher


Examples of net.canarymod.hook.Dispatcher

    }
    public static interface IDispatcher {
        public void execute(PluginListener listener, Hook hook);
    }
    public Dispatcher getDispatcher(final IDispatcher impl){
        return new Dispatcher(){
            public void execute(PluginListener listener, Hook hook){
                impl.execute(listener, hook);
            }
        };
    }
View Full Code Here

Examples of net.sf.cglib.proxy.Dispatcher

  }

  public Object newInstance(Class<?>[] interfacesToProxy, final Object target) {
    Enhancer enhancer = new Enhancer();
    enhancer.setInterfaces(interfacesToProxy);
    enhancer.setCallback(new Dispatcher() {
      public Object loadObject() throws Exception {
        return target;
      }
    });
    return enhancer.create();
View Full Code Here

Examples of net.tomp2p.connection.Dispatcher

   *
   * @param unreachablePeerId the unreachable peer
   * @return forwarder
   */
  private BaseRelayForwarderRPC extractRelayForwarder(final Message message) {
    final Dispatcher dispatcher = peer.connectionBean().dispatcher();
    final Map<Integer, DispatchHandler> ioHandlers = dispatcher.searchHandlerMap(peer.peerID(), message.recipient().peerId());
    for (DispatchHandler handler : ioHandlers.values()) {
      if (handler instanceof BaseRelayForwarderRPC) {
        return (BaseRelayForwarderRPC) handler;
      }
    }
View Full Code Here

Examples of net.yacy.peers.dht.Dispatcher

        this.yc = new Network(this);
        InstantBusyThread.oneTimeJob(this, "loadSeedLists", Network.log, 0);
        //final long startedSeedListAquisition = System.currentTimeMillis();

        // init a DHT transmission dispatcher
        this.dhtDispatcher = (this.peers.sizeConnected() == 0) ? null : new Dispatcher(
                this.indexSegments.segment(Segments.Process.LOCALCRAWLING),
                this.peers,
                true,
                10000);
View Full Code Here

Examples of org.apache.chemistry.opencmis.server.shared.Dispatcher

                throw new ServletException("Could not load call context handler: " + e, e);
            }
        }

        // initialize the dispatcher
        dispatcher = new Dispatcher();

        try {
            dispatcher.addResource(RESOURCE_TYPES, METHOD_GET, RepositoryService.class,
                    "getTypeChildren");
            dispatcher.addResource(RESOURCE_TYPESDESC, METHOD_GET, RepositoryService.class,
View Full Code Here

Examples of org.apache.felix.http.base.internal.dispatch.Dispatcher

    public HttpServiceController(BundleContext bundleContext)
    {
        this.bundleContext = bundleContext;
        this.registry = new HandlerRegistry();
        this.dispatcher = new Dispatcher(this.registry);
        this.serviceProps = new Hashtable<String, Object>();
        this.contextAttributeListener = new ServletContextAttributeListenerManager(bundleContext);
        this.requestListener = new ServletRequestListenerManager(bundleContext);
        this.requestAttributeListener = new ServletRequestAttributeListenerManager(bundleContext);
        this.sessionListener = new HttpSessionListenerManager(bundleContext);
View Full Code Here

Examples of org.apache.hadoop.hive.ql.lib.Dispatcher

      // Reparse text, passing null for context to avoid clobbering
      // the top-level token stream.
      ASTNode tree = pd.parse(viewText, null);
      tree = ParseUtils.findRootNonNullToken(tree);
      viewTree = tree;
      Dispatcher nodeOriginDispatcher = new Dispatcher() {
        public Object dispatch(Node nd, java.util.Stack<Node> stack,
            Object... nodeOutputs) {
          ((ASTNode) nd).setOrigin(viewOrigin);
          return null;
        }
View Full Code Here

Examples of org.apache.hadoop.hive.ql.lib.Dispatcher

    opRules.put(new RuleRegExp(new String("R11"), "MAPJOIN%SEL%"),
        MapJoinFactory.getMapJoin());

    // The dispatcher fires the processor corresponding to the closest matching
    // rule and passes the context along
    Dispatcher disp = new DefaultRuleDispatcher(new GenMROperator(), opRules,
        procCtx);

    GraphWalker ogw = new GenMapRedWalker(disp);
    ArrayList<Node> topNodes = new ArrayList<Node>();
    topNodes.addAll(topOps.values());
View Full Code Here

Examples of org.apache.hadoop.hive.ql.lib.Dispatcher

public class CommonJoinResolver implements PhysicalPlanResolver {
  @Override
  public PhysicalContext resolve(PhysicalContext pctx) throws SemanticException {

    // create dispatcher and graph walker
    Dispatcher disp = new CommonJoinTaskDispatcher(pctx);
    TaskGraphWalker ogw = new TaskGraphWalker(disp);

    // get all the tasks nodes from root task
    ArrayList<Node> topNodes = new ArrayList<Node>();
    topNodes.addAll(pctx.rootTasks);
View Full Code Here

Examples of org.apache.hadoop.hive.ql.lib.Dispatcher

    // generates the plan from the operator tree
    Map<Rule, NodeProcessor> rules = new LinkedHashMap<Rule, NodeProcessor>();

    // The dispatcher fires the processor corresponding to the closest matching
    // rule and passes the context along
    Dispatcher disp = new DefaultRuleDispatcher(this, rules, null);
    GraphWalker ogw = new DefaultGraphWalker(disp);

    // Create a list of topop nodes
    ArrayList<Node> topNodes = new ArrayList<Node>();
    topNodes.add(tree);
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.