Examples of Cluster


Examples of org.apache.whirr.Cluster

            throws IOException, GFacHandlerException, ConfigurationException, InterruptedException, TransformerException, ParserConfigurationException {
        ClusterSpec hadoopClusterSpec =
                whirrConfigurationToClusterSpec(hostDescription, workingDirectory);
        ClusterController hadoopClusterController =
                createClusterController(hadoopClusterSpec.getServiceName());
        Cluster hadoopCluster =  hadoopClusterController.launchCluster(hadoopClusterSpec);

        logger.info(String.format("Started cluster of %s instances.\n",
                hadoopCluster.getInstances().size()));

        File siteXML = new File(workingDirectory, "hadoop-site.xml");
        clusterPropertiesToHadoopSiteXml(hadoopCluster.getConfiguration(), siteXML);

        return siteXML;
    }
View Full Code Here

Examples of org.apache.whirr.service.Cluster

      // TODO: retry
      throw new IOException(e);
    }

    LOG.info("Completed launch of {}", clusterSpec.getClusterName());
    return new Cluster(getInstances(nodes));
  }
View Full Code Here

Examples of org.atmosphere.annotation.Cluster

        if (broadcastAnnotation != null) {
           
            List<ClusterBroadcastFilter> clusterBroadcastFilters =
                    new ArrayList<ClusterBroadcastFilter>();
           
            Cluster clusterAnnotation = ctx.getActionAnnotation(Cluster.class);
            if (clusterAnnotation != null) {
                Class<? extends ClusterBroadcastFilter>[] clusterFilters = clusterAnnotation.value();
                for (Class<? extends ClusterBroadcastFilter> c : clusterFilters) {
                    try {
                        ClusterBroadcastFilter cbf = c.newInstance();
                        InjectorProvider.getInjector().inject(cbf);
                        cbf.setUri(clusterAnnotation.name());
                        clusterBroadcastFilters.add(cbf);
                    } catch (Throwable t) {
                        logger.warn("Invalid ClusterBroadcastFilter", t);
                    }
                }
View Full Code Here

Examples of org.axonframework.eventhandling.Cluster

        // to choose the name of the created thread.
        ExecutorService executor = Executors.newSingleThreadExecutor();

        // we initialize the asynchronous cluster. We don't need transactions (NoTransactionManager) and allow all
        // events to be handled concurrently (FullConcurrencyPolicy).
        Cluster asyncCluster = new AsynchronousCluster("async", executor, new FullConcurrencyPolicy());
        // and we initialize a simple cluster
        Cluster standardCluster = new SimpleCluster("simple");

        // to make sure Listeners are assigned to their respective cluster, we create a number of selectors that we
        // combine into a single ClusterSelector using a CompositeClusterSelector
        ClusterSelector clusterSelector = new CompositeClusterSelector(Arrays.<ClusterSelector>asList(
                // this one will accept
View Full Code Here

Examples of org.carrot2.core.Cluster

        .getLexicalData(LanguageCode.MALTESE);

    for (String word : wordsToCheck.split(",")) {
      if (!lexicalData.isCommonWord(new MutableCharArray(word))
          && !lexicalData.isStopLabel(word)) {
        clusters.add(new Cluster(word));
      }
    }
  }
View Full Code Here

Examples of org.cytoscape.ClusterViz.internal.Cluster

        List clusters = panel.getClusters();
        registrar.unregisterService(panel, CytoPanelComponent.class);
        mcodeUtil.removeNetworkResult(resultId);
        if (clusters != null)
        {
          Cluster c;
          for (Iterator iterator = clusters.iterator(); iterator.hasNext(); c.dispose())
            c = (Cluster)iterator.next();

        }
      }
    }
View Full Code Here

Examples of org.fnlp.nlp.similarity.Cluster

      float v = it.value()/totalword;
      it.setValue(v);
      int key = it.key();
      if(key<0)
        continue;
      Cluster cluster = new Cluster(key,v,alpahbet.lookupString(key));
      clusters.put(key, cluster);
    }

    TIntObjectIterator<TIntFloatHashMap> it1 = pcc.iterator();
    while(it1.hasNext()){
View Full Code Here

Examples of org.glassfish.loadbalancer.admin.cli.beans.Cluster

      ClusterReader[] cRdrs = lbRdr.getClusters();

      if ((cRdrs != null) && (cRdrs.length > 0)) {
        Cluster[] cls = new Cluster[cRdrs.length];
        for (int i = 0; i < cRdrs.length; i++) {
          cls[i] = new Cluster();
          cRdrs[i].accept(new ClusterVisitor(cls[i]));
        }
        _lb.setCluster(cls);
      }
    }
View Full Code Here

Examples of org.jclouds.cloudstack.domain.Cluster

         .payload(payloadFromResource("/listclustersresponse.json"))
         .statusCode(200).build();

      Set<Cluster> actual = requestSendsResponse(request, response).listClusters();

      Cluster cluster1 = Cluster.builder().id("1").name("Xen Clust 1").podId("1").podName("Dev Pod 1").zoneId("1").zoneName("Dev Zone 1").hypervisor("XenServer").clusterType(Host.ClusterType.CLOUD_MANAGED).allocationState(AllocationState.ENABLED).managedState(Cluster.ManagedState.MANAGED).build();
      Cluster cluster2 = Cluster.builder().id("2").name("Xen Clust 1").podId("2").podName("Dev Pod 2").zoneId("2").zoneName("Dev Zone 2").hypervisor("XenServer").clusterType(Host.ClusterType.CLOUD_MANAGED).allocationState(AllocationState.ENABLED).managedState(Cluster.ManagedState.MANAGED).build();
      ImmutableSet<Cluster> expected = ImmutableSet.of(cluster1, cluster2);

      assertEquals(actual, expected);
   }
View Full Code Here

Examples of org.jclouds.rackspace.cloudbigdata.v1.domain.Cluster

        
         if (status.equals(cluster.getStatus())) {
            return true;
         }
         else {
            Cluster ClusterUpdated = clusterApi.get(cluster.getId());
            checkNotNull(ClusterUpdated, "Cluster %s not found.", cluster.getId());
           
            return status.equals(ClusterUpdated.getStatus());
         }
      }
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.