Java 类com.google.common.base.Preconditions 实例源码

项目:chvote-protocol-poc    文件:DefaultAuthority.java   
@Override
public FinalizationCodePart handleConfirmation(Integer voterIndex, Confirmation confirmation)
        throws IncorrectConfirmationRuntimeException {
    Preconditions.checkState(publicCredentials != null,
            "The public credentials need to have been retrieved first");
    Stopwatch stopwatch = Stopwatch.createStarted();
    List<BigInteger> publicConfirmationCredentials =
            publicCredentials.stream().map(p -> p.y).collect(Collectors.toList());

    if (!voteConfirmationAuthorityAlgorithms.checkConfirmation(voterIndex, confirmation,
            publicConfirmationCredentials, ballotEntries, confirmationEntries)) {
        throw new IncorrectConfirmationRuntimeException("Confirmation for voter " + voterIndex + " was deemed invalid");
    }
    stopwatch.stop();
    confirmationVerificationTimes.add(stopwatch.elapsed(TimeUnit.MILLISECONDS));

    confirmationEntries.add(new ConfirmationEntry(voterIndex, confirmation));

    stopwatch.reset().start();
    FinalizationCodePart finalization = voteConfirmationAuthorityAlgorithms.getFinalization(voterIndex, electorateData.getP(), ballotEntries);
    stopwatch.stop();
    finalizationComputationTimes.add(stopwatch.elapsed(TimeUnit.MILLISECONDS));

    return finalization;
}
项目:clearwsd    文件:KMeans.java   
private void initialize() {
    Preconditions.checkState(points.size() > kVal,
            "k-value is greater than or equal to number of points (%d >= %d).", kVal, points.size());
    Stopwatch sw = Stopwatch.createStarted();
    List<KmeansPoint<T>> pool = new ArrayList<>(points);
    KmeansPoint<T> sample = VectorMathUtils.sampleUniform(pool, random);
    pool.remove(sample);

    KmeansCentroid point = KmeansCentroid.centroid(sample, 0);
    centroids = Lists.newArrayList(point);
    for (int i = 1; i < kVal; ++i) {
        if (kMeansPlusPlus) {
            KmeansCentroid current = point;
            pool.parallelStream().forEach(p -> distanceToCentroid(p, current));
            sample = samplePoint(i - 1);
        } else {
            sample = VectorMathUtils.sampleUniform(pool, random);
        }
        pool.remove(sample);

        point = KmeansCentroid.centroid(sample, i);
        centroids.add(point);
    }
    log.info("Initialized centroids in {}.", sw);
}
项目:chvote-protocol-poc    文件:Conversion.java   
/**
 * Algorithm 4.6: ToString
 *
 * @param x       the integer to convert
 * @param k       the required String size
 * @param upper_a the alphabet to be used
 * @return a string of length k, using alphabet A, and representing x
 */
public String toString(BigInteger x, int k, List<Character> upper_a) {
    Preconditions.checkArgument(x.signum() >= 0, "x should be a non-negative integer");
    int alphabetSize = upper_a.size();
    BigInteger N = BigInteger.valueOf(alphabetSize);
    Preconditions.checkArgument(N.pow(k).compareTo(x) >= 0,
            "x is too large to be encoded with k characters of alphabet upper_a");

    StringBuilder sb = new StringBuilder(k);
    BigInteger current = x;
    for (int i = 1; i <= k; i++) {
        BigInteger[] divideAndRemainder = current.divideAndRemainder(N);
        current = divideAndRemainder[0];
        // always insert before the previous character
        sb.insert(0, upper_a.get(divideAndRemainder[1].intValue()));
    }

    return sb.toString();
}
项目:integrations    文件:CaseChargesWithDispo2010.java   
public static String getMiddleName( Row row ) {
    String name = row.getAs( "Defendant Name" );
    if ( name == null ) { return null; }
    name = name.replace( " Jr", "" );
    name = name.replace( " JR", "" );
    name = name.replace( " Sr", "" );
    name = name.replace( " SR", "" );

    List<String> names = nameSplitter.splitToList( name );
    Preconditions.checkState( names.size() > 0, "Must have at least some parts of name" );
    StringBuilder sb = new StringBuilder();
    for ( int i = 2; i < names.size(); ++i ) {
        sb.append( names.get( i ) ).append( " " );
    }

    return sb.toString().trim();
}
项目:hashsdn-controller    文件:ConfigurationImpl.java   
@Override
public ShardStrategy getStrategyForPrefix(@Nonnull final DOMDataTreeIdentifier prefix) {
    Preconditions.checkNotNull(prefix, "Prefix cannot be null");
    // FIXME using prefix tables like in mdsal will be better
    Entry<DOMDataTreeIdentifier, PrefixShardConfiguration> bestMatchEntry =
            new SimpleEntry<>(
                    new DOMDataTreeIdentifier(prefix.getDatastoreType(), YangInstanceIdentifier.EMPTY), null);

    for (Entry<DOMDataTreeIdentifier, PrefixShardConfiguration> entry : prefixConfigMap.entrySet()) {
        if (entry.getKey().contains(prefix) && entry.getKey().getRootIdentifier().getPathArguments().size()
                > bestMatchEntry.getKey().getRootIdentifier().getPathArguments().size()) {
            bestMatchEntry = entry;
        }
    }

    if (bestMatchEntry.getValue() == null) {
        return null;
    }
    return new PrefixShardStrategy(ClusterUtils
            .getCleanShardName(bestMatchEntry.getKey().getRootIdentifier()),
            bestMatchEntry.getKey().getRootIdentifier());
}
项目:mynlp    文件:ViterbiBestPathComputer.java   
/**
 * 从后到前。根据权重获取最优路径
 *
 * @param wordnet
 * @return
 */
private Wordpath buildPath(Wordnet wordnet) {
    //从后到前,获得完整的路径
    Wordpath wordPath = new Wordpath(wordnet, this);

    Vertex last = null;

    Vertex point = wordnet.getEndRow().first();

    while (point != null) {
        last = point;
        wordPath.combine(point);
        point = point.from;
    }

    // 最后一个point必定指向start节点
    Preconditions.checkState(last == wordnet.getBeginRow().first(), "非完整路径");

    return wordPath;
}
项目:QDrill    文件:AbstractMuxExchange.java   
@Override
public ParallelizationInfo getReceiverParallelizationInfo(List<DrillbitEndpoint> senderFragmentEndpoints) {
  Preconditions.checkArgument(senderFragmentEndpoints != null && senderFragmentEndpoints.size() > 0,
      "Sender fragment endpoint list should not be empty");

  // We want to run one mux receiver per Drillbit endpoint.
  // Identify the number of unique Drillbit endpoints in sender fragment endpoints.
  List<DrillbitEndpoint> drillbitEndpoints = ImmutableSet.copyOf(senderFragmentEndpoints).asList();

  List<EndpointAffinity> affinities = Lists.newArrayList();
  for(DrillbitEndpoint ep : drillbitEndpoints) {
    affinities.add(new EndpointAffinity(ep, Double.POSITIVE_INFINITY));
  }

  return ParallelizationInfo.create(affinities.size(), affinities.size(), affinities);
}
项目:dremio-oss    文件:ProvisioningServiceImpl.java   
@Override
public ClusterEnriched resizeCluster(ClusterId clusterId, int newContainersCount) throws ProvisioningHandlingException {
  // get info about cluster
  // children should do the rest
  Preconditions.checkNotNull(clusterId, "id is required");
  final Cluster cluster = store.get(clusterId);
  if (cluster == null) {
    throw new ProvisioningHandlingException("Cluster " + clusterId + " is not found. Nothing to resize");
  }

  cluster.getClusterConfig().getClusterSpec().setContainerCount(newContainersCount);
  final ProvisioningServiceDelegate service = concreteServices.get(cluster.getClusterConfig().getClusterType());
  if (service == null) {
    throw new ProvisioningHandlingException("Can not find service implementation for: " + cluster.getClusterConfig().getClusterType());
  }

  if (newContainersCount <= 0) {
    logger.info("Since number of requested containers to resize == 0. Stopping cluster");
    service.stopCluster(cluster);
  } else {
    service.resizeCluster(cluster);
  }
  store.put(clusterId, cluster);
  return service.getClusterInfo(cluster);
}
项目:hadoop    文件:ByteArrayManager.java   
/**
 * Recycle the given byte array.
 * 
 * The byte array may or may not be allocated
 * by the {@link Impl#newByteArray(int)} method.
 * 
 * This is a non-blocking call.
 */
@Override
public int release(final byte[] array) {
  Preconditions.checkNotNull(array);
  if (LOG.isDebugEnabled()) {
    debugMessage.get().append("recycle: array.length=").append(array.length);
  }

  final int freeQueueSize;
  if (array.length == 0) {
    freeQueueSize = -1;
  } else {
    final FixedLengthManager manager = managers.get(array.length, false);
    freeQueueSize = manager == null? -1: manager.recycle(array);
  }

  if (LOG.isDebugEnabled()) {
    debugMessage.get().append(", freeQueueSize=").append(freeQueueSize);
    logDebugMessage();
  }
  return freeQueueSize;
}
项目:hadoop-oss    文件:CryptoInputStream.java   
/**
 * Do the decryption using inBuffer as input and outBuffer as output.
 * Upon return, inBuffer is cleared; the decrypted data starts at 
 * outBuffer.position() and ends at outBuffer.limit();
 */
private void decrypt(Decryptor decryptor, ByteBuffer inBuffer, 
    ByteBuffer outBuffer, byte padding) throws IOException {
  Preconditions.checkState(inBuffer.position() >= padding);
  if(inBuffer.position() == padding) {
    // There is no real data in inBuffer.
    return;
  }
  inBuffer.flip();
  outBuffer.clear();
  decryptor.decrypt(inBuffer, outBuffer);
  inBuffer.clear();
  outBuffer.flip();
  if (padding > 0) {
    /*
     * The plain text and cipher text have a 1:1 mapping, they start at the 
     * same position.
     */
    outBuffer.position(padding);
  }
}
项目:spark_deep    文件:MessageWithHeader.java   
/**
 * This code is more complicated than you would think because we might require multiple
 * transferTo invocations in order to transfer a single MessageWithHeader to avoid busy waiting.
 *
 * The contract is that the caller will ensure position is properly set to the total number
 * of bytes transferred so far (i.e. value returned by transfered()).
 */
@Override
public long transferTo(final WritableByteChannel target, final long position) throws IOException {
  Preconditions.checkArgument(position == totalBytesTransferred, "Invalid position.");
  // Bytes written for header in this call.
  long writtenHeader = 0;
  if (header.readableBytes() > 0) {
    writtenHeader = copyByteBuf(header, target);
    totalBytesTransferred += writtenHeader;
    if (header.readableBytes() > 0) {
      return writtenHeader;
    }
  }

  // Bytes written for body in this call.
  long writtenBody = 0;
  if (body instanceof FileRegion) {
    writtenBody = ((FileRegion) body).transferTo(target, totalBytesTransferred - headerLength);
  } else if (body instanceof ByteBuf) {
    writtenBody = copyByteBuf((ByteBuf) body, target);
  }
  totalBytesTransferred += writtenBody;

  return writtenHeader + writtenBody;
}
项目:helper    文件:FunctionalCommandBuilderImpl.java   
@Override
public FunctionalCommandBuilder<T> assertSender(Predicate<T> test, String failureMessage) {
    Preconditions.checkNotNull(test, "test");
    Preconditions.checkNotNull(failureMessage, "failureMessage");
    predicates.add(context -> {
        //noinspection unchecked
        T sender = (T) context.sender();
        if (test.test(sender)) {
            return true;
        }

        context.reply(failureMessage);
        return false;
    });
    return this;
}
项目:gitplex-mit    文件:ReceiveCommand.java   
@Override
public Void call() {
    Preconditions.checkNotNull(input);
    Preconditions.checkNotNull(output);

    Commandline cmd = cmd();
    cmd.addArgs("receive-pack", "--stateless-rpc", ".");

    cmd.execute(output, new LineConsumer() {

        @Override
        public void consume(String line) {
            logger.error(line);
        }

    }, input).checkReturnCode();

    return null;
}
项目:FirstAid    文件:FirstAidRegistryImpl.java   
@Override
public void registerDebuff(@Nonnull EnumDebuffSlot slot, @Nonnull IDebuffBuilder abstractBuilder) {
    DebuffBuilder builder;
    try {
        builder = (DebuffBuilder) abstractBuilder;
    } catch (ClassCastException e) {
        throw new IllegalArgumentException("Builder must an instance of the default builder received via DebuffBuilderFactory!", e);
    }
    //Build the finished debuff
    FirstAid.logger.debug("Building debuff from mod {} for slot {} with potion effect {}, type = {}", CommonUtils.getActiveModidSafe(), slot, builder.potionName, builder.isOnHit ? "OnHit" : "Constant");
    BooleanSupplier isEnabled = builder.isEnabledSupplier;
    if (isEnabled == null)
        isEnabled = () -> true;

    Preconditions.checkArgument(!builder.map.isEmpty(), "Failed to register debuff with condition has set");
    IDebuff debuff;
    if (builder.isOnHit) {
        debuff = new OnHitDebuff(builder.potionName, builder.map, isEnabled, builder.sound);
    } else {
        Preconditions.checkArgument(builder.sound == null, "Tried to register constant debuff with sound effect.");
        debuff = new ConstantDebuff(builder.potionName, builder.map, isEnabled);
    }
    registerDebuff(slot, debuff);
}
项目:Elasticsearch    文件:BigLongArray.java   
@Override
public void fill(long fromIndex, long toIndex, long value) {
    Preconditions.checkArgument(fromIndex <= toIndex);
    if (fromIndex == toIndex) {
        return; // empty range
    }
    final int fromPage = pageIndex(fromIndex);
    final int toPage = pageIndex(toIndex - 1);
    if (fromPage == toPage) {
        Arrays.fill(pages[fromPage], indexInPage(fromIndex), indexInPage(toIndex - 1) + 1, value);
    } else {
        Arrays.fill(pages[fromPage], indexInPage(fromIndex), pages[fromPage].length, value);
        for (int i = fromPage + 1; i < toPage; ++i) {
            Arrays.fill(pages[i], value);
        }
        Arrays.fill(pages[toPage], 0, indexInPage(toIndex - 1) + 1, value);
    }
}
项目:gitplex-mit    文件:DependencyUtils.java   
public static <K, T extends DependencyAware<K>> Set<K> getTransitiveDependents(
        Map<K, Set<K>> dependentMap, K dependency) {
    Set<K> transitiveDependents = new HashSet<>();

    transitiveDependents.addAll(Preconditions.checkNotNull(dependentMap.get(dependency)));
    while (true) {
        Set<K> newTransitiveDependents = new HashSet<>(transitiveDependents);
        for (K dependent: transitiveDependents) {
            newTransitiveDependents.addAll(Preconditions.checkNotNull(dependentMap.get(dependent)));
        }
        if (!transitiveDependents.equals(newTransitiveDependents)) {
            transitiveDependents = newTransitiveDependents;
        } else {
            break;
        }
    }
    return transitiveDependents;
}
项目:cucumber-framework-java    文件:RecoverFromStaleElement.java   
@Override
public List<String> getLocatorsList( WebElement element )
{
    Preconditions.checkNotNull( element, "WebElement cannot be null" );
    logger.trace( "parsing locator list for element -> {}", toString() );
    String[] str = toString().replaceAll( "(\\[{1,20}(FirefoxDriver.*?|ChromeDriver.*?|SafariDriver.*?|InternetExplorerDriver.*?)\\] -> )", "" )
            .replaceAll( "(])\\1+", "$1" )
            .replaceAll( "(])\\1+", "$1" )
            .replaceAll( " -> ", "|" )
            .split( "\\|", -1 );

    List<String> list = Lists.newArrayList();
    for( String s : str )
    {
        if( !s.contains( "[" ) && s.endsWith( "]" ) )
        {
            list.add( s.replaceFirst( "\\]", "" ) );
        } else
        {
            list.add( s );
        }
    }

    return list;
}
项目:dremio-oss    文件:HashAggTemplate.java   
public HashAggTemplate(){
  try{
    Class<?> clazz = null;
    for(Class<?> c : getClass().getDeclaredClasses()){
      if(c.getSimpleName().equals("BatchHolder")){
        clazz = c;
        break;
      }
    }

    Preconditions.checkNotNull(clazz);
    this.innerConstructor = (Constructor<BatchHolder>) clazz.getConstructor(this.getClass());
    innerConstructor.setAccessible(true);
  }catch(Exception ex){
    throw Throwables.propagate(ex);
  }
}
项目:NBANDROID-V2    文件:AndroidConfigProvider.java   
private static void saveConfig(AuxiliaryProperties props, LaunchConfiguration l, String suffix) {
    Preconditions.checkNotNull(props);
    switch (l.getLaunchAction()) {
        case DO_NOTHING:
            props.put(AndroidProjectProperties.PROP_LAUNCH_ACTION + suffix,
                    AndroidProjectProperties.LAUNCH_ACTION_DO_NOTHING, false);
            break;
        case MAIN:
            props.put(AndroidProjectProperties.PROP_LAUNCH_ACTION + suffix,
                    AndroidProjectProperties.LAUNCH_ACTION_MAIN, false);
            break;
        case ACTIVITY:
            props.put(AndroidProjectProperties.PROP_LAUNCH_ACTION + suffix,
                    l.getActivityName(), false);
            break;
    }
    if (!LaunchConfiguration.MODE_DEBUG.equals(l.getMode())) {
        props.put(AndroidProjectProperties.PROP_LAUNCH_MODE + suffix, l.getMode(), false);
    }
    props.put(AndroidProjectProperties.PROP_LAUNCH_TARGET_MODE + suffix, l.getTargetMode().toString(), false);
    props.put(AndroidProjectProperties.PROP_EMULATOR_OPTIONS + suffix, l.getEmulatorOptions(), false);
    props.put(AndroidProjectProperties.PROP_INSTR_RUNNER + suffix, l.getInstrumentationRunner(), false);
}
项目:sstable-adaptor    文件:SyncUtil.java   
public static void force(FileChannel fc, boolean metaData) throws IOException
{
    Preconditions.checkNotNull(fc);
    if (SKIP_SYNC)
    {
        if (!fc.isOpen())
            throw new ClosedChannelException();
    }
    else
    {
        fc.force(metaData);
    }
}
项目:helper    文件:JsonBuilder.java   
default JsonArrayBuilder addStrings(Iterable<String> iterable) {
    Preconditions.checkNotNull(iterable, "iterable");
    for (String e : iterable) {
        add(e);
    }
    return this;
}
项目:hashsdn-controller    文件:DataTreeChangeListenerProxy.java   
DataTreeChangeListenerProxy(final ActorContext actorContext, final T listener,
        final YangInstanceIdentifier registeredPath) {
    super(listener);
    this.actorContext = Preconditions.checkNotNull(actorContext);
    this.registeredPath = Preconditions.checkNotNull(registeredPath);
    this.dataChangeListenerActor = actorContext.getActorSystem().actorOf(
            DataTreeChangeListenerActor.props(getInstance(), registeredPath)
                .withDispatcher(actorContext.getNotificationDispatcherPath()));

    LOG.debug("{}: Created actor {} for DTCL {}", actorContext.getDatastoreContext().getLogicalStoreType(),
            dataChangeListenerActor, listener);
}
项目:dremio-oss    文件:YarnController.java   
public TwillRunnerService startTwillRunner(YarnConfiguration yarnConfiguration) {
  String zkStr = dremioConfig.getString(DremioConfig.ZOOKEEPER_QUORUM);
  String clusterId = yarnConfiguration.get(YARN_CLUSTER_ID);
  Preconditions.checkNotNull(clusterId, "Cluster ID can not be null");
  TwillRunnerService twillRunner = new YarnTwillRunnerService(yarnConfiguration, zkStr);
  TwillRunnerService previousOne = twillRunners.putIfAbsent(new ClusterId(clusterId), twillRunner);
  if (previousOne == null) {
    // start one we are planning to add - if it is already in collection it should be started
    twillRunner.start();
    return twillRunner;
  }
  return previousOne;
}
项目:EchoPet    文件:PetRegistry.java   
public IPet spawn(PetType petType, final Player owner){
    Preconditions.checkNotNull(petType, "Pet type must not be null.");
    Preconditions.checkNotNull(owner, "Owner type must not be null.");
    final PetRegistrationEntry registrationEntry = getRegistrationEntry(petType);
    if(registrationEntry == null){
        // Pet type not registered
        return null;
    }
    return performRegistration(registrationEntry, new Callable<IPet>(){

        public IPet call() throws Exception{
            return registrationEntry.createFor(owner);
        }
    });
}
项目:apkfile    文件:ResourceConfiguration.java   
private String unpackLanguageOrRegion(byte[] value, int base) {
    Preconditions.checkState(value.length == 2, "Language or region value must be 2 bytes.");
    if (value[0] == 0 && value[1] == 0) {
        return "";
    }
    if ((UnsignedBytes.toInt(value[0]) & 0x80) != 0) {
        byte[] result = new byte[3];
        result[0] = (byte) (base + (value[1] & 0x1F));
        result[1] = (byte) (base + ((value[1] & 0xE0) >>> 5) + ((value[0] & 0x03) << 3));
        result[2] = (byte) (base + ((value[0] & 0x7C) >>> 2));
        return new String(result, US_ASCII);
    }
    return new String(value, US_ASCII);
}
项目:de.flapdoodle.solid    文件:Sites.java   
public static FormatterOfProperty formatterOfProperty(Site site) {
    DefaultObjectFormatter defaultFormatter=new DefaultObjectFormatter();
    return (name,formatterName) -> {
        if (formatterName.isPresent()) {
            return Preconditions.checkNotNull(site.config().formatters().formatters().get(formatterName.get()),"could not get formatter %s",formatterName.get());
        }
        Maybe<String> defaultFormatterName = Maybe.ofNullable(site.config().defaultFormatter().get(name));
        if (defaultFormatterName.isPresent()) {
            return Preconditions.checkNotNull(site.config().formatters().formatters().get(defaultFormatterName.get()),"could not get formatter %s",defaultFormatterName.get());
        }
        return defaultFormatter;
    };
}
项目:gitplex-mit    文件:ProjectBranchesPage.java   
public ProjectBranchesPage(PageParameters params) {
    super(params);

    baseBranch = params.get(PARAM_BASE).toString();
    if (baseBranch == null)
        baseBranch = Preconditions.checkNotNull(getProject().getDefaultBranch());

    if (getProject().getDefaultBranch() == null) 
        throw new RestartResponseException(NoBranchesPage.class, paramsOf(getProject()));
}
项目:hadoop    文件:AMRMClientImpl.java   
@Override
public synchronized void releaseAssignedContainer(ContainerId containerId) {
  Preconditions.checkArgument(containerId != null,
      "ContainerId can not be null.");
  pendingRelease.add(containerId);
  release.add(containerId);
}
项目:stroom-stats    文件:MultiPartIdentifier.java   
public MultiPartIdentifier(Object... values) {
    Preconditions.checkNotNull(values);
    if (values.length == 0){
        String valuesStr = values == null ? "NULL" : toHumanReadable();
        throw new IllegalArgumentException(String.format("values %s must contain at least one element", valuesStr));
    }
    this.values = values;
}
项目:vscrawler    文件:AnnotationSeedProcessor.java   
private void judgeDownloader(Class<? extends AbstractAutoProcessModel> aClass) {
    Method[] methods = aClass.getMethods();
    for (final Method method : methods) {
        if (method.getAnnotation(DownLoadMethod.class) == null) {
            continue;
        }
        Preconditions.checkArgument(String.class.isAssignableFrom(method.getReturnType()));
        Preconditions.checkArgument(method.getParameterTypes().length >= 2);
        Preconditions.checkArgument(method.getParameterTypes()[0].isAssignableFrom(Seed.class));
        Preconditions.checkArgument(method.getParameterTypes()[1].isAssignableFrom(CrawlerSession.class));

        downloader = new Downloader() {
            @Override
            public String download(Seed seed, AbstractAutoProcessModel model, CrawlerSession crawlerSession) {
                try {
                    return (String) method.invoke(model, seed, crawlerSession);
                } catch (Exception e) {
                    throw new RuntimeException("invoke download method :" + method.toGenericString() + " failed", e);
                }
            }
        };
        return;
    }

    downloader = new Downloader() {
        @Override
        public String download(Seed seed, AbstractAutoProcessModel model, CrawlerSession crawlerSession) {
            return crawlerSession.getCrawlerHttpClient().get(seed.getData());
        }
    };
}
项目:hashsdn-controller    文件:AbstractClientConnection.java   
private AbstractClientConnection(final AbstractClientConnection<T> oldConn, final TransmitQueue newQueue) {
    this.context = Preconditions.checkNotNull(oldConn.context);
    this.cookie = Preconditions.checkNotNull(oldConn.cookie);
    this.queue = Preconditions.checkNotNull(newQueue);
    // Will be updated in finishReplay if needed.
    this.lastReceivedTicks = oldConn.lastReceivedTicks;
}
项目:buckaroo    文件:RenderableException.java   
static Component render(final Throwable throwable) {
    Preconditions.checkNotNull(throwable);
    if (throwable instanceof RenderableException) {
        return ((RenderableException) throwable).render();
    }
    final String message = throwable.getMessage() == null ?
        throwable.toString() :
        throwable.getMessage();
    return Text.of(message, Color.RED);
}
项目:hashsdn-controller    文件:ResolveDataChangeState.java   
private ResolveDataChangeState(final YangInstanceIdentifier nodeId,
        final Iterable<Builder> inheritedSub, final Collection<Builder> inheritedOne,
        final Collection<RegistrationTreeNode<DataChangeListenerRegistration<?>>> nodes) {
    this.nodeId = Preconditions.checkNotNull(nodeId);
    this.nodes = Preconditions.checkNotNull(nodes);
    this.inheritedSub = Preconditions.checkNotNull(inheritedSub);
    this.inheritedOne = Preconditions.checkNotNull(inheritedOne);

    /*
     * Collect the nodes which need to be propagated from us to the child.
     */
    final Map<DataChangeListenerRegistration<?>, Builder> sub = new HashMap<>();
    final Map<DataChangeListenerRegistration<?>, Builder> one = new HashMap<>();
    final Map<DataChangeListenerRegistration<?>, Builder> base = new HashMap<>();
    for (RegistrationTreeNode<DataChangeListenerRegistration<?>> n : nodes) {
        for (DataChangeListenerRegistration<?> l : n.getRegistrations()) {
            final Builder b = DOMImmutableDataChangeEvent.builder(DataChangeScope.BASE);
            switch (l.getScope()) {
            case BASE:
                base.put(l, b);
                break;
            case ONE:
                one.put(l, b);
                break;
            case SUBTREE:
                sub.put(l, b);
                break;
            }
        }
    }

    baseBuilders = maybeEmpty(base);
    oneBuilders = maybeEmpty(one);
    subBuilders = maybeEmpty(sub);
}
项目:dremio-oss    文件:PipelineCreator.java   
private Pipeline get(PhysicalOperator operator) throws Exception {
  try(RollbackCloseable closeable = AutoCloseables.rollbackable(AutoCloseables.all(operators))) {
    final CreatorVisitor visitor = new CreatorVisitor();
    OpPipe opPipe = operator.accept(visitor, null);
    Preconditions.checkNotNull(opPipe.getPipe());
    Pipeline driver = new Pipeline(opPipe.getPipe(), visitor.terminal, operators, sharedResourcesContext);
    closeable.commit();
    return driver;
  }
}
项目:CustomWorldGen    文件:ContextKey.java   
public static <E> ContextKey<E> create(String id, Class<E> c)
{
    Preconditions.checkNotNull(id, "ContextKey's ID can't be null!");
    Preconditions.checkNotNull(c, "ContextKey's Type can't be null!");

    if(id.isEmpty())
    {
        throw new IllegalArgumentException("ContextKey's ID can't be blank!");
    }

    return new ContextKey<E>(id, c);
}
项目:android-chunk-utils    文件:Chunk.java   
/**
 * Writes the type and header size. We don't know how big this chunk will be (it could be
 * different since the last time we checked), so this needs to be passed in.
 *
 * @param output The buffer that will be written to.
 * @param chunkSize The total size of this chunk in bytes, including the header.
 */
protected final void writeHeader(ByteBuffer output, int chunkSize) {
  int start = output.position();
  output.putShort(getType().code());
  output.putShort((short) headerSize);
  output.putInt(chunkSize);
  writeHeader(output);
  int headerBytes = output.position() - start;
  Preconditions.checkState(headerBytes == getHeaderSize(),
      "Written header is wrong size. Got %s, want %s", headerBytes, getHeaderSize());
}
项目:Reer    文件:ReportDaemonStatusClient.java   
public ReportDaemonStatusClient(DaemonRegistry daemonRegistry, DaemonConnector connector, IdGenerator<?> idGenerator, DocumentationRegistry documentationRegistry) {
    Preconditions.checkNotNull(daemonRegistry, "DaemonRegistry must not be null");
    Preconditions.checkNotNull(connector, "DaemonConnector must not be null");
    Preconditions.checkNotNull(idGenerator, "IdGenerator must not be null");
    Preconditions.checkNotNull(documentationRegistry, "DocumentationRegistry must not be null");

    this.daemonRegistry = daemonRegistry;
    this.connector = connector;
    this.idGenerator = idGenerator;
    this.reportStatusDispatcher = new ReportStatusDispatcher();
    this.documentationRegistry = documentationRegistry;
}
项目:buckaroo    文件:GenericEventRenderer.java   
public static Component render(final DependencyInstallationEvent event) {
    Preconditions.checkNotNull(event);
    return StackLayout.of(
        FlowLayout.of(
            Text.of("Downloading: ", Color.CYAN),
            render(event.progress.getValue0().identifier)),
        ListLayout.of(render(event.progress.getValue1())));
}
项目:chvote-protocol-poc    文件:ByteArrayUtils.java   
public static byte[] xor(byte[] a, byte[] b) {
    byte[] local_a = Arrays.copyOf(a, a.length);
    byte[] local_b = Arrays.copyOf(b, b.length);
    Preconditions.checkArgument(local_a.length == local_b.length,
            "The arrays should have the same size. |a| = [" + local_a.length + "], |b| = [" + local_b.length + "]");
    byte[] result = new byte[local_a.length];
    for (int i = 0; i < local_a.length; i++) {
        result[i] = (byte) (local_a[i] ^ local_b[i]);
    }
    return result;
}
项目:hadoop    文件:BlockPoolSliceStorage.java   
/**
 * Delete all files and directories in the trash directories.
 */
public void restoreTrash() {
  for (StorageDirectory sd : storageDirs) {
    File trashRoot = getTrashRootDir(sd);
    try {
      Preconditions.checkState(!(trashRoot.exists() && sd.getPreviousDir().exists()));
      restoreBlockFilesFromTrash(trashRoot);
      FileUtil.fullyDelete(getTrashRootDir(sd));
    } catch (IOException ioe) {
      LOG.warn("Restoring trash failed for storage directory " + sd);
    }
  }
}