Examples of cleanup()


Examples of org.apache.felix.cm.integration.helper.ManagedServiceThread.cleanup()

            final boolean isConfigured = mt.isConfigured();
            final ArrayList<Dictionary> configs = mt.getConfigs();

            // terminate mt to ensure no further config updates
            mt.cleanup();

            TestCase.assertTrue( "Last update call must have been with configuration",  isConfigured);

            if ( configs.size() == 0 )
            {
View Full Code Here

Examples of org.apache.hadoop.hbase.monitoring.MonitoredTask.cleanup()

              + " or change your hadoop jars to start properly", t);
      } else {
        abort("Unhandled exception. Starting shutdown.", t);
      }
    } finally {
      startupStatus.cleanup();
     
      stopChores();
      // Wait for all the remaining region servers to report in IFF we were
      // running a cluster shutdown AND we were NOT aborting.
      if (!this.abort && this.serverManager != null &&
View Full Code Here

Examples of org.apache.hadoop.hdfs.DFSTestUtil.cleanup()

      // bring up data nodes & cleanup cluster
      cluster.startDataNodes(conf, 4, true, null, null);
      cluster.waitActive();
      cluster.waitClusterUp();
      fs = cluster.getFileSystem();
      util.cleanup(fs, "/srcdat");
    } finally {
      if (fs != null) {try{fs.close();} catch(Exception e){}}
      if (cluster != null) { cluster.shutdown(); }
    }
  }
View Full Code Here

Examples of org.apache.hadoop.hive.ql.stats.StatsAggregator.cleanUp()

    StatsAggregator statsAggregator;
    String statsImplementationClass = HiveConf.getVar(config, HiveConf.ConfVars.HIVESTATSDBCLASS);
    StatsFactory.setImplementation(statsImplementationClass, config);
    statsAggregator = StatsFactory.getStatsAggregator();
    if (statsAggregator.connect(config)) {
      statsAggregator.cleanUp(jobID + Path.SEPARATOR); // Adding the path separator to avoid an Id being a prefix of another ID
    }
  }
}
View Full Code Here

Examples of org.apache.hadoop.mapred.gridmix.SleepJob.SleepReducer.cleanup()

    // status has been changed
    assertEquals("Sleeping... " + sleeper + " ms left", context.getStatus());
    // should sleep 0.9 sec

    assertTrue(System.currentTimeMillis() >= (start + sleeper));
    test.cleanup(context);
    // status has been changed again

    assertEquals("Slept for " + sleeper, context.getStatus());

  }
View Full Code Here

Examples of org.apache.helix.provisioning.yarn.AppLauncher.cleanup()

    launcher.launch();
    Runtime.getRuntime().addShutdownHook(new Thread(new Runnable() {

      @Override
      public void run() {
        launcher.cleanup();
      }
    }));

    final ApplicationSpec appSpec = launcher.getApplicationSpec();
View Full Code Here

Examples of org.apache.jackrabbit.oak.plugins.segment.file.FileStore.cleanup()

            }

            System.out.println("    -> cleaning up");
            store = new FileStore(directory, 256, false);
            try {
                store.cleanup();
            } finally {
                store.close();
            }

            System.out.println("    after  " + Arrays.toString(directory.list()));
View Full Code Here

Examples of org.apache.karaf.cave.server.api.CaveRepository.cleanup()

        CaveRepository repository = this.getRepository(name);
        if (repository == null) {
            throw new IllegalArgumentException("Cave repository " + name + " doesn't exist");
        }
        repositories.remove(name);
        repository.cleanup();
    }

    /**
     * Install a Cave repository in the OBR service.
     * NB: this method allows refresh the repository in the OBR "client".
View Full Code Here

Examples of org.apache.mahout.df.mapreduce.partial.Step0Job.Step0Mapper.cleanup()

        mapper.map(key, reader.getCurrentValue(), context);

        size++;
      }

      mapper.cleanup(context);

      // validate the mapper's output
      assertEquals(p, context.keys[p]);
      assertEquals(firstKey.longValue(), context.values[p].getFirstId());
      assertEquals(size, context.values[p].getSize());
View Full Code Here

Examples of org.apache.manifoldcf.agents.common.XMLStream.cleanup()

            {
              long time = System.currentTimeMillis();
              throw new ServiceInterruption(e.getMessage(),e,time + 300000L,time + 12L * 60000L,-1,false);
            }
          } finally {
            x.cleanup();
          }
        } finally {
          try {
            is.close();
          } catch (IllegalStateException e) {
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.