Examples of HeartBeater


Examples of com.alimama.mdrill.index.utils.HeartBeater

    }
    TermInfosWriter.setNotUseQuick(false);
    String fieldStrs = conf.get("higo.index.fields");
    String[] fieldslist = fieldStrs.split(",");
    this.documentConverter = new DocumentConverter(fieldslist,"solrconfig.xml", "schema.xml");
    heartBeater = new HeartBeater(context);
    heartBeater.needHeartBeat();

    shardWriter = this.initShardWriter(context);
    shardWriter.getDir().setAllowLinks(true);
  }
View Full Code Here

Examples of com.alimama.mdrill.index.utils.HeartBeater

    if(!isNotFdtMode)
    {
      TermInfosWriter.setSkipInterVal(16);
    }

    heartBeater = new HeartBeater(context);
    heartBeater.needHeartBeat();
    this.doclistcache=new DocumentList();
    this.ramMerger = new RamWriter();

    String[] fieldslist = fieldStrs.split(",");
View Full Code Here

Examples of com.opengamma.livedata.client.Heartbeater

    expirationManager.setTimeoutExtension(300);
    HeartbeatReceiver receiver = new HeartbeatReceiver(expirationManager);
    DirectInvocationByteArrayMessageSender conduit = new DirectInvocationByteArrayMessageSender(receiver);
    ValueDistributor valueDistributor = new ValueDistributor();
    Timer t = new Timer("HeartbeatConduitTest");
    new Heartbeater(valueDistributor, new HeartbeatSender(conduit, OpenGammaFudgeContext.getInstance()), t, 100);

    // subscribe on the client side - starts sending heartbeats
    LiveDataSpecification subscription = new LiveDataSpecification(
        dataServer.getDefaultNormalizationRuleSetId(),
        ExternalId.of(identificationDomain, "USSw5 Curncy"));
View Full Code Here

Examples of com.opengamma.livedata.client.Heartbeater

    HeartbeatReceiver receiver = new HeartbeatReceiver(expirationManager);
    DirectInvocationByteArrayMessageSender conduit = new DirectInvocationByteArrayMessageSender(receiver);
    ValueDistributor valueDistributor = new ValueDistributor();
    Timer t = new Timer("HeartbeatConduitTest");
    new Heartbeater(valueDistributor, new HeartbeatSender(conduit, OpenGammaFudgeContext.getInstance()), t, 100);

    // subscribe on the client side - starts sending heartbeats
    LiveDataSpecification subscription = new LiveDataSpecification(
        dataServer.getDefaultNormalizationRuleSetId(),
        ExternalId.of(identificationDomain, "USSw5 Curncy"));
View Full Code Here

Examples of com.splout.db.common.HeartBeater

  @Override
  public RecordWriter<ITuple, NullWritable> getRecordWriter(TaskAttemptContext context) throws IOException,
      InterruptedException {

    long waitTimeHeartBeater = context.getConfiguration().getLong(HeartBeater.WAIT_TIME_CONF, 5000);
    heartBeater = new HeartBeater(context, waitTimeHeartBeater);
    heartBeater.needHeartBeat();
    conf = context.getConfiguration();
    this.context = context;
   
    outputFormat.setConf(context.getConfiguration());
View Full Code Here

Examples of org.apache.hadoop.hive.ql.exec.Heartbeater

    long cpuMsec = -1;
    int numMap = -1;
    int numReduce = -1;
    List<ClientStatsPublisher> clientStatPublishers = getClientStatPublishers();

    Heartbeater heartbeater = new Heartbeater(th.getTxnManager(), job);

    while (!rj.isComplete()) {
      try {
        Thread.sleep(pullInterval);
      } catch (InterruptedException e) {
      }
      heartbeater.heartbeat();

      if (initializing && rj.getJobState() == JobStatus.PREP) {
        // No reason to poll untill the job is initialized
        continue;
      } else {
View Full Code Here

Examples of org.apache.hadoop.hive.ql.exec.Heartbeater

    int failedCounter = 0;
    int rc = 0;
    DAGStatus.State lastState = null;
    String lastReport = null;
    Set<StatusGetOpts> opts = new HashSet<StatusGetOpts>();
    Heartbeater heartbeater = new Heartbeater(txnMgr, conf);

    shutdownList.add(dagClient);

    console.printInfo("\n");
    perfLogger.PerfLogBegin(CLASS_NAME, PerfLogger.TEZ_RUN_DAG);
    perfLogger.PerfLogBegin(CLASS_NAME, PerfLogger.TEZ_SUBMIT_TO_RUNNING);

    while(true) {

      try {
        status = dagClient.getDAGStatus(opts);
        Map<String, Progress> progressMap = status.getVertexProgress();
        DAGStatus.State state = status.getState();
        heartbeater.heartbeat();

        if (state != lastState || state == RUNNING) {
          lastState = state;

          switch(state) {
View Full Code Here

Examples of org.apache.hadoop.hive.ql.exec.Heartbeater

    int failedCounter = 0;
    int rc = 0;
    DAGStatus.State lastState = null;
    String lastReport = null;
    Set<StatusGetOpts> opts = new HashSet<StatusGetOpts>();
    Heartbeater heartbeater = new Heartbeater(txnMgr, conf);
    long startTime = 0;
    boolean isProfileEnabled = conf.getBoolVar(conf, HiveConf.ConfVars.TEZ_EXEC_SUMMARY);
    boolean inPlaceUpdates = conf.getBoolVar(conf, HiveConf.ConfVars.TEZ_EXEC_INPLACE_PROGRESS);
    boolean wideTerminal = false;
    boolean isTerminal = inPlaceUpdates == true ? isUnixTerminal() : false;

    // we need at least 80 chars wide terminal to display in-place updates properly
    if (isTerminal) {
      if (getTerminalWidth() >= MIN_TERMINAL_WIDTH) {
        wideTerminal = true;
      }
    }

    boolean inPlaceEligible = false;
    if (inPlaceUpdates && isTerminal && wideTerminal && !console.getIsSilent()) {
      inPlaceEligible = true;
    }

    shutdownList.add(dagClient);

    console.printInfo("\n");
    perfLogger.PerfLogBegin(CLASS_NAME, PerfLogger.TEZ_RUN_DAG);
    perfLogger.PerfLogBegin(CLASS_NAME, PerfLogger.TEZ_SUBMIT_TO_RUNNING);

    while (true) {

      try {
        status = dagClient.getDAGStatus(opts);
        Map<String, Progress> progressMap = status.getVertexProgress();
        DAGStatus.State state = status.getState();
        heartbeater.heartbeat();

        if (state != lastState || state == RUNNING) {
          lastState = state;

          switch (state) {
View Full Code Here

Examples of org.apache.hadoop.hive.ql.exec.Heartbeater

    long cpuMsec = -1;
    int numMap = -1;
    int numReduce = -1;
    List<ClientStatsPublisher> clientStatPublishers = getClientStatPublishers();

    Heartbeater heartbeater = new Heartbeater(th.getTxnManager(), job);

    while (!rj.isComplete()) {
      try {
        Thread.sleep(pullInterval);
      } catch (InterruptedException e) {
      }
      heartbeater.heartbeat();

      if (initializing && rj.getJobState() == JobStatus.PREP) {
        // No reason to poll untill the job is initialized
        continue;
      } else {
View Full Code Here

Examples of org.apache.hadoop.hive.ql.exec.Heartbeater

    long cpuMsec = -1;
    int numMap = -1;
    int numReduce = -1;
    List<ClientStatsPublisher> clientStatPublishers = getClientStatPublishers();

    Heartbeater heartbeater = new Heartbeater(th.getTxnManager(), job);

    while (!rj.isComplete()) {
      try {
        Thread.sleep(pullInterval);
      } catch (InterruptedException e) {
      }
      heartbeater.heartbeat();

      if (initializing && rj.getJobState() == JobStatus.PREP) {
        // No reason to poll untill the job is initialized
        continue;
      } else {
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.