当前位置: 首页>>代码示例>>Java>>正文


Java TimeUnit.SECONDS属性代码示例

本文整理汇总了Java中java.util.concurrent.TimeUnit.SECONDS属性的典型用法代码示例。如果您正苦于以下问题:Java TimeUnit.SECONDS属性的具体用法?Java TimeUnit.SECONDS怎么用?Java TimeUnit.SECONDS使用的例子?那么恭喜您, 这里精选的属性代码示例或许可以为您提供帮助。您也可以进一步了解该属性所在java.util.concurrent.TimeUnit的用法示例。


在下文中一共展示了TimeUnit.SECONDS属性的15个代码示例,这些例子默认根据受欢迎程度排序。您可以为喜欢或者感觉有用的代码点赞,您的评价将有助于系统推荐出更棒的Java代码示例。

示例1: canBeSerialized

@Test
public void canBeSerialized() throws Exception {
  long timeout = 2;
  TimeUnit timeUnit = TimeUnit.SECONDS;
  boolean lookingForStuckThread = true;

  SerializableTimeout instance = SerializableTimeout.builder().withTimeout(timeout, timeUnit)
      .withLookingForStuckThread(lookingForStuckThread).build();

  assertThat(readField(Timeout.class, instance, FIELD_TIMEOUT)).isEqualTo(timeout);
  assertThat(readField(Timeout.class, instance, FIELD_TIME_UNIT)).isEqualTo(timeUnit);
  assertThat(readField(Timeout.class, instance, FIELD_LOOK_FOR_STUCK_THREAD))
      .isEqualTo(lookingForStuckThread);

  SerializableTimeout cloned = (SerializableTimeout) SerializationUtils.clone(instance);

  assertThat(readField(Timeout.class, cloned, FIELD_TIMEOUT)).isEqualTo(timeout);
  assertThat(readField(Timeout.class, cloned, FIELD_TIME_UNIT)).isEqualTo(timeUnit);
  assertThat(readField(Timeout.class, cloned, FIELD_LOOK_FOR_STUCK_THREAD))
      .isEqualTo(lookingForStuckThread);
}
 
开发者ID:ampool,项目名称:monarch,代码行数:21,代码来源:SerializableTimeoutTest.java

示例2:

@Benchmark
@Warmup(iterations = 10)
@Measurement(iterations = 10)
@Fork(1)
@Threads(1)
@BenchmarkMode(Mode.Throughput)
@OutputTimeUnit(TimeUnit.SECONDS)
public int measureCreateEmptyNodesAndRelationships() throws IOException {
    int user;
    for (user = 0; user < userCount; user++) {
        db.addNode("user" + user);
    }
    for (user = 0; user < userCount; user++) {
        for (int like = 0; like < friendsCount; like++) {
            db.addRelationship("FRIENDS", "user" + user, "user" + rand.nextInt(userCount));
        }
    }
    return user;
}
 
开发者ID:maxdemarzi,项目名称:GuancialeDB,代码行数:19,代码来源:GuancialeDBBenchmark.java

示例3: LogRollerRunnable

public LogRollerRunnable( Application csapApp ) {

		this.csapApp = csapApp;

		long initialDelay = 5;
		long interval = csapApp.lifeCycleSettings().getLogRotationMinutes();

		TimeUnit logRotationTimeUnit = TimeUnit.MINUTES;

		if ( Application.isRunningOnDesktop() ) {
			logger.warn( "Setting DESKTOP to seconds" );
			logRotationTimeUnit = TimeUnit.SECONDS;
		}

		logger.warn(
			"Scheduling logrotates to be triggered every {} {}. Logs only rotated if size exceeds threshold (default is 10mb)",
			interval, logRotationTimeUnit );

		ScheduledFuture<?> jobHandle = scheduledExecutorService
			.scheduleAtFixedRate(
				() -> executeLogRotateForAllServices(),
				initialDelay,
				interval,
				logRotationTimeUnit );

	}
 
开发者ID:csap-platform,项目名称:csap-core,代码行数:26,代码来源:LogRollerRunnable.java

示例4: testShutdown2

@Test
public void testShutdown2() throws InterruptedException {
  ex = new ScheduledThreadPoolExecutorWithKeepAlive(50, 1, TimeUnit.SECONDS,
      Executors.defaultThreadFactory());
  ex.submit(new Runnable() {
    public void run() {
      try {
        Thread.sleep(3000);
      } catch (InterruptedException e) {
        fail("interrupted");
      }
    }
  });
  // give it a chance to get in the worker pool
  Thread.sleep(500);
  ex.shutdown();
  long start = System.nanoTime();
  assertTrue(ex.awaitTermination(10, TimeUnit.SECONDS));
  long elapsed = System.nanoTime() - start;
  assertTrue("Shutdown did not wait to task to complete. Only waited "
      + TimeUnit.NANOSECONDS.toMillis(elapsed), TimeUnit.SECONDS.toNanos(2) < elapsed);
}
 
开发者ID:ampool,项目名称:monarch,代码行数:22,代码来源:ScheduledThreadPoolExecutorWithKeepAliveJUnitTest.java

示例5: ThreadPoolManager

private ThreadPoolManager()
{
	_effectsScheduledThreadPool = new ScheduledThreadPoolExecutor(Config.THREAD_P_EFFECTS, new PriorityThreadFactory("EffectsSTPool", Thread.NORM_PRIORITY));
	_generalScheduledThreadPool = new ScheduledThreadPoolExecutor(Config.THREAD_P_GENERAL, new PriorityThreadFactory("GerenalSTPool", Thread.NORM_PRIORITY));
	_ioPacketsThreadPool = new ThreadPoolExecutor(Config.IO_PACKET_THREAD_CORE_SIZE, Integer.MAX_VALUE,5L, TimeUnit.SECONDS,new LinkedBlockingQueue<Runnable>(),new PriorityThreadFactory("I/O Packet Pool",Thread.NORM_PRIORITY+1));
	_generalPacketsThreadPool = new ThreadPoolExecutor(Config.GENERAL_PACKET_THREAD_CORE_SIZE, Config.GENERAL_PACKET_THREAD_CORE_SIZE+2,15L, TimeUnit.SECONDS,new LinkedBlockingQueue<Runnable>(),new PriorityThreadFactory("Normal Packet Pool",Thread.NORM_PRIORITY+1));
	_generalThreadPool = new ThreadPoolExecutor(Config.GENERAL_THREAD_CORE_SIZE, Config.GENERAL_THREAD_CORE_SIZE+2,5L, TimeUnit.SECONDS,new LinkedBlockingQueue<Runnable>(),new PriorityThreadFactory("General Pool",Thread.NORM_PRIORITY));
	// will be really used in the next AI implementation.
	_aiThreadPool = new ThreadPoolExecutor(1, Config.AI_MAX_THREAD,10L, TimeUnit.SECONDS,new LinkedBlockingQueue<Runnable>());
	_aiScheduledThreadPool = new ScheduledThreadPoolExecutor(Config.AI_MAX_THREAD, new PriorityThreadFactory("AISTPool", Thread.NORM_PRIORITY));
}
 
开发者ID:L2jBrasil,项目名称:L2jBrasil,代码行数:11,代码来源:ThreadPoolManager.java

示例6: testConcurrentRepeatedTasks

@Test
public void testConcurrentRepeatedTasks() throws InterruptedException, ExecutionException {
  ex = new ScheduledThreadPoolExecutorWithKeepAlive(50, 1, TimeUnit.SECONDS,
      Executors.defaultThreadFactory());

  final AtomicInteger counter = new AtomicInteger();
  Runnable waitForABit = new Runnable() {
    public void run() {
      try {
        counter.incrementAndGet();
        Thread.sleep(500);
      } catch (InterruptedException e) {
        fail("interrupted");
      }
    }
  };

  Future[] futures = new Future[50];
  for (int i = 0; i < 50; i++) {
    futures[i] = ex.scheduleAtFixedRate(waitForABit, 0, 1, TimeUnit.SECONDS);
  }

  Thread.sleep(10000);

  for (int i = 0; i < 50; i++) {
    futures[i].cancel(true);
  }

  System.err.println("Counter = " + counter);
  assertTrue("Tasks did not execute in parallel. Expected more than 300 executions, got "
      + counter.get(), counter.get() > 300);

  assertEquals(50, ex.getLargestPoolSize());

  // now make sure we expire back down.
  Thread.sleep(5000);
  assertEquals(1, ex.getPoolSize());
}
 
开发者ID:ampool,项目名称:monarch,代码行数:38,代码来源:ScheduledThreadPoolExecutorWithKeepAliveJUnitTest.java

示例7: properties

@Test
public void properties() {
    Timed<Integer> timed = new Timed<Integer>(1, 5, TimeUnit.SECONDS);

    assertEquals(1, timed.value().intValue());
    assertEquals(5, timed.time());
    assertEquals(5000, timed.time(TimeUnit.MILLISECONDS));
    assertSame(TimeUnit.SECONDS, timed.unit());
}
 
开发者ID:akarnokd,项目名称:RxJava3-preview,代码行数:9,代码来源:TimedTest.java

示例8: build

@Override
public ExchangeAttribute build(String token) {
    if (token.equals(RESPONSE_TIME_MILLIS) || token.equals(RESPONSE_TIME_MILLIS_SHORT)) {
        return new ResponseTimeAttribute(TimeUnit.MILLISECONDS);
    }
    if (token.equals(RESPONSE_TIME_SECONDS_SHORT)) {
        return new ResponseTimeAttribute(TimeUnit.SECONDS);
    }
    return null;
}
 
开发者ID:lamsfoundation,项目名称:lams,代码行数:10,代码来源:ResponseTimeAttribute.java

示例9: initInternal

@Override
protected void initInternal() throws LifecycleException {
	BlockingQueue<Runnable> startStopQueue = new LinkedBlockingQueue<Runnable>();
	startStopExecutor = new ThreadPoolExecutor(getStartStopThreadsInternal(), getStartStopThreadsInternal(), 10,
			TimeUnit.SECONDS, startStopQueue, new StartStopThreadFactory(getName() + "-startStop-"));
	startStopExecutor.allowCoreThreadTimeOut(true);
	super.initInternal();
}
 
开发者ID:how2j,项目名称:lazycat,代码行数:8,代码来源:ContainerBase.java

示例10: DownloadTask

/**
 * 构建文件下载器,适用于下载单个大文件
 *
 * @param downloadUrl 下载路径
 * @param fileSaveDir 文件保存目录
 * @param threadNum   下载线程数
 */
public DownloadTask(Context context, String downloadUrl, File fileSaveDir, int threadNum) {
    try {
        System.out.println("DownloadTask>>>" + downloadUrl);
        this.context = context;
        this.downloadUrl = downloadUrl;
        fileService = FileService.getInstance();
        URL url = new URL(this.downloadUrl);
        if (!fileSaveDir.exists())
            fileSaveDir.mkdirs();
        this.threadnum = threadNum;
        threadPool = new ThreadPoolExecutor(threadnum + 1, threadnum + 1, 20, TimeUnit.SECONDS, new LinkedBlockingDeque<Runnable>(), new ThreadPoolExecutor.CallerRunsPolicy());
        HttpURLConnection conn = getConnectionAndConnect(url, 3);
        this.fileSize = conn.getContentLength();//根据响应获取文件大小
        if (this.fileSize <= 0)
            throw new RuntimeException("Unkown file size ");

        String filename = getFileName(conn);
        this.saveFile = new File(fileSaveDir, filename);/* 保存文件 */
        Map<Integer, Integer> logdata = fileService.getData(downloadUrl);
        if (logdata.size() > 0) {
            for (Map.Entry<Integer, Integer> entry : logdata.entrySet())
                data.put(entry.getKey(), entry.getValue());
        }
        this.block = (this.fileSize % threadnum) == 0 ? this.fileSize / threadnum : this.fileSize / threadnum + 1;
        if (this.data.size() == threadnum) {
            for (int i = 0; i < threadnum; i++) {
                this.downloadSize += this.data.get(i);
            }
            Log.i(TAG, "已经下载的长度" + this.downloadSize);
        }
    } catch (Exception e) {
        e.printStackTrace();
        throw new RuntimeException("don't connection this url");
    }
}
 
开发者ID:LingjuAI,项目名称:AssistantBySDK,代码行数:42,代码来源:DownloadTask.java

示例11: testUpdate

public static void testUpdate() throws Exception {
        EventBus updateEventBus = new EventBus();
//        int maxSize = 10000;
//        int corePoolSize = 100;
        int maxSize = 20000;
        int corePoolSize = 20;
        long keepAliveTime = 60;
        TimeUnit timeUnit = TimeUnit.SECONDS;
        String poolName = "update";
        DisruptorExecutorService disruptorExcutorService = new DisruptorExecutorService(poolName, corePoolSize);
        int cycleSleepTime = 1000 / Constants.cycle.cycleSize;
        DisruptorDispatchThread dispatchThread = new DisruptorDispatchThread(updateEventBus, disruptorExcutorService
                , cycleSleepTime, cycleSleepTime*1000);
        disruptorExcutorService.setDisruptorDispatchThread(dispatchThread);
        UpdateService updateService = new UpdateService(dispatchThread, disruptorExcutorService);

        updateEventBus.addEventListener(new DispatchCreateEventListener(dispatchThread, updateService));
        updateEventBus.addEventListener(new DispatchUpdateEventListener(dispatchThread, updateService));
        updateEventBus.addEventListener(new DispatchFinishEventListener(dispatchThread, updateService));

//        updateService.notifyStart();
        updateService.start();
        long updateMaxSize = 100;
        for (long i = 0; i < maxSize; i++) {
            IntegerUpdate integerUpdate = new IntegerUpdate(i, updateMaxSize);
            EventParam<IntegerUpdate> param = new EventParam<IntegerUpdate>(integerUpdate);
            CycleEvent cycleEvent = new CycleEvent(Constants.EventTypeConstans.readyCreateEventType, integerUpdate.getUpdateId(), param);
            updateService.addReadyCreateEvent(cycleEvent);
        }


        while (true) {
            Thread.currentThread().sleep(100);
            updateService.toString();
        }

//        updateService.stop();
    }
 
开发者ID:jwpttcg66,项目名称:game-executor,代码行数:38,代码来源:DisruptorTest.java

示例12: QueuesExecutorService

protected QueuesExecutorService(int corePoolSize, int maximumPoolSize,Queue<Runnable> bossQueue) {
    this(corePoolSize, maximumPoolSize, DEFAULT_KEEP_ALIVE_SEC, TimeUnit.SECONDS, 
    		Executors.defaultThreadFactory(),DEFAULT_waitConditionStrategy,
    		bossQueue,DEFAULT_IndexQueueGroupManager,DEFAULT_KeyQueueGroupManager,null);
}
 
开发者ID:juebanlin,项目名称:util4j,代码行数:5,代码来源:QueuesExecutorService.java

示例13:

@Measurement(iterations = 20000, time = 1, timeUnit = TimeUnit.SECONDS)
  @Benchmark
  public void testMethod(TestState s) throws Exception {
  	Calculator c = getCalculator(s);
s.valueSink = s.valueSink + handleRequest(c, 1312, 2435);
  }
 
开发者ID:dodie,项目名称:jvm-dynamic-optimizations-performance-test,代码行数:6,代码来源:NMorphicInlinig.java

示例14: testIllegalArgumentCreation

@Test(expected = IllegalArgumentException.class)
public void testIllegalArgumentCreation() {
    FakeLoad f1 = new SimpleFakeLoad(-1L, TimeUnit.SECONDS);
}
 
开发者ID:msigwart,项目名称:fakeload,代码行数:4,代码来源:SimpleFakeLoadTest.java

示例15: MusicActivityJob

public MusicActivityJob(AvaIre avaire) {
    super(avaire, 30, 30, TimeUnit.SECONDS);
}
 
开发者ID:avaire,项目名称:avaire,代码行数:3,代码来源:MusicActivityJob.java


注:本文中的java.util.concurrent.TimeUnit.SECONDS属性示例由纯净天空整理自Github/MSDocs等开源代码及文档管理平台,相关代码片段筛选自各路编程大神贡献的开源项目,源码版权归原作者所有,传播和使用请参考对应项目的License;未经允许,请勿转载。