Examples of StorageTestUtil


Examples of org.apache.aurora.scheduler.storage.testing.StorageTestUtil

  private SchedulerLifecycle schedulerLifecycle;

  @Before
  public void setUp() {
    driverFactory = createMock(DriverFactory.class);
    storageUtil = new StorageTestUtil(this);
    shutdownRegistry = createMock(ShutdownSystem.class);
    driver = createMock(SettableDriver.class);
    leaderControl = createMock(LeaderControl.class);
    schedulerDriver = createMock(SchedulerDriver.class);
    delayedActions = createMock(DelayedActions.class);
View Full Code Here

Examples of org.apache.aurora.scheduler.storage.testing.StorageTestUtil

  public void setUp() {
    future = createMock(new Clazz<ScheduledFuture<?>>() { });
    executor = createMock(ScheduledExecutorService.class);
    clock = new FakeClock();
    stateManager = createMock(StateManager.class);
    storageUtil = new StorageTestUtil(this);
    storageUtil.expectOperations();
    pruner = new HistoryPruner(
        executor,
        stateManager,
        clock,
View Full Code Here

Examples of org.apache.aurora.scheduler.storage.testing.StorageTestUtil

  private TaskVars vars;
  private Map<String, Supplier<Long>> globalCounters;

  @Before
  public void setUp() {
    storageUtil = new StorageTestUtil(this);
    trackedStats = createMock(StatsProvider.class);
    vars = new TaskVars(storageUtil.storage, trackedStats);

    storageUtil.expectOperations();
    globalCounters = Maps.newHashMap();
View Full Code Here

Examples of org.apache.aurora.scheduler.storage.testing.StorageTestUtil

  private BackoffStrategy backoff;
  private RescheduleCalculator rescheduleCalculator;

  @Before
  public void setUp() {
    storageUtil = new StorageTestUtil(this);
    backoff = createMock(BackoffStrategy.class);
    rescheduleCalculator = new RescheduleCalculatorImpl(
        storageUtil.storage,
        new RescheduleCalculatorImpl.RescheduleCalculatorSettings(
            backoff,
View Full Code Here

Examples of org.apache.aurora.scheduler.storage.testing.StorageTestUtil

  private MesosSchedulerImpl scheduler;

  @Before
  public void setUp() {
    storageUtil = new StorageTestUtil(this);
    final Lifecycle lifecycle =
        new Lifecycle(createMock(Command.class), createMock(UncaughtExceptionHandler.class));
    systemLauncher = createMock(TaskLauncher.class);
    userLauncher = createMock(TaskLauncher.class);
    eventSink = createMock(EventSink.class);
View Full Code Here

Examples of org.apache.aurora.scheduler.storage.testing.StorageTestUtil

  private EventSink eventSink;
  private AttributeAggregate emptyJob;

  @Before
  public void setUp() throws Exception {
    storageUtil = new StorageTestUtil(this);
    stateManager = createMock(StateManager.class);
    assigner = createMock(TaskAssigner.class);
    offerQueue = createMock(OfferQueue.class);
    reservationDuration = Amount.of(2L, Time.MINUTES);
    halfReservationDuration = Amount.of(1L, Time.MINUTES);
View Full Code Here

Examples of org.apache.aurora.scheduler.storage.testing.StorageTestUtil

  private GcExecutorLauncher gcExecutorLauncher;
  private AtomicLong lostTasks;

  @Before
  public void setUp() {
    storageUtil = new StorageTestUtil(this);
    clock = new FakeClock();
    storageUtil.expectOperations();
    driver = createMock(Driver.class);
    statsProvider = createMock(StatsProvider.class);
    lostTasks = new AtomicLong();
View Full Code Here

Examples of org.apache.aurora.scheduler.storage.testing.StorageTestUtil

  @Before
  public void setUp() throws Exception {
    StatsProvider statsProvider = createMock(StatsProvider.class);
    StatsProvider untracked = createMock(StatsProvider.class);
    MetricCalculatorSettings settings = new MetricCalculatorSettings(10000);
    storageUtil = new StorageTestUtil(this);
    calculator = new MetricCalculator(storageUtil.storage, clock, settings, statsProvider);
    expect(statsProvider.untracked()).andReturn(untracked).anyTimes();
    expect(untracked.makeGauge(EasyMock.anyString(), EasyMock.<Supplier<Number>>anyObject()))
        .andReturn(EasyMock.<Stat<Number>>anyObject())
        .anyTimes();
View Full Code Here

Examples of org.apache.aurora.scheduler.storage.testing.StorageTestUtil

  private SlaModule module;
  private EventSink eventSink;

  @Before
  public void setUp() throws Exception {
    storageUtil = new StorageTestUtil(this);
    clock = new FakeClock();
    statsProvider = createMock(StatsProvider.class);
    module = new SlaModule(Amount.of(5L, Time.MILLISECONDS));
    injector = Guice.createInjector(
        ImmutableList.<Module>builder()
View Full Code Here

Examples of org.apache.aurora.scheduler.storage.testing.StorageTestUtil

  private InetSocketAddress httpServer;
  private Capture<HostChangeMonitor<ServiceInstance>> schedulerWatcher;

  @Before
  public void setUp() throws Exception {
    storage = new StorageTestUtil(this);
    final DynamicHostSet<ServiceInstance> schedulers =
        createMock(new Clazz<DynamicHostSet<ServiceInstance>>() {
        });

    Injector injector = Guice.createInjector(
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.