Examples of StorageTestUtil


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

  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 TaskHistoryPruner(
        executor,
        stateManager,
        clock,
View Full Code Here

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

import static org.easymock.EasyMock.expect;

public class JobUpdateHistoryPrunerTest extends EasyMockTest {
  @Test
  public void testExecution() throws Exception {
    StorageTestUtil storageUtil = new StorageTestUtil(this);
    storageUtil.expectOperations();

    final ScheduledExecutorService executor = createMock(ScheduledExecutorService.class);
    FakeScheduledExecutor executorClock =
        FakeScheduledExecutor.scheduleAtFixedRateExecutor(executor, 2);
View Full Code Here

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

  private StatsProvider statsProvider;

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

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

  @Before
  public void setUp() throws Exception {
    rescheduleCalculator = createMock(RescheduleCalculator.class);
    clock = new FakeClock();
    executor = createMock(ScheduledExecutorService.class);
    storageUtil = new StorageTestUtil(this);
    storageUtil.expectOperations();
    stateManager = createMock(StateManager.class);
    throttler = new TaskThrottler(
        rescheduleCalculator,
        clock,
View Full Code Here

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

  private AtomicLong lostTasks;
  private AtomicLong insufficientOffers;

  @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

  protected Capture<HostChangeMonitor<ServiceInstance>> schedulerWatcher;
  protected AuroraAdmin.Iface thrift;

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

    injector = Guice.createInjector(
View Full Code Here

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

  }

  @Before
  public void setUp() {
    scheduler = createMock(Scheduler.class);
    storage = new StorageTestUtil(this);
    driverFactory = createMock(DriverFactory.class);
    schedulerDriver = createMock(SchedulerDriver.class);
    driverService = new SchedulerDriverService(scheduler, storage.storage, SETTINGS, driverFactory);
  }
View Full Code Here

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

  private MaintenanceController maintenance;
  private EventSink eventSink;

  @Before
  public void setUp() throws Exception {
    storageUtil = new StorageTestUtil(this);
    storageUtil.expectOperations();
    stateManager = createMock(StateManager.class);

    Injector injector = Guice.createInjector(
        new PubsubEventModule(false),
View Full Code Here

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

    };
    LogManager logManager = new LogManager(log, streamManagerFactory);

    schedulingService = createMock(SchedulingService.class);
    snapshotStore = createMock(new Clazz<SnapshotStore<Snapshot>>() { });
    storageUtil = new StorageTestUtil(this);
    eventSink = createMock(EventSink.class);

    logStorage = new LogStorage(
        logManager,
        schedulingService,
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.