javax.annotation.Nullable Java Examples
The following examples show how to use
javax.annotation.Nullable.
You can vote up the ones you like or vote down the ones you don't like,
and go to the original project or source file by following the links above each example. You may check out the related API usage on the sidebar.
Example #1
Source File: MzRangeFormulaCalculatorModule.java From mzmine3 with GNU General Public License v2.0 | 5 votes |
@Nullable public static Range<Double> getMzRangeFromFormula(String formula, IonizationType ionType, MZTolerance mzTolerance, Integer charge) { if ((formula == null) || (ionType == null) || (mzTolerance == null) || (charge == null)) return null; String ionizedFormula = FormulaUtils.ionizeFormula(formula, ionType, charge); double calculatedMZ = FormulaUtils.calculateExactMass(ionizedFormula, charge) / charge; return mzTolerance.getToleranceRange(calculatedMZ); }
Example #2
Source File: ClickEventStatisticsSerializationSchema.java From flink-playgrounds with Apache License 2.0 | 5 votes |
@Override public ProducerRecord<byte[], byte[]> serialize( final ClickEventStatistics message, @Nullable final Long timestamp) { try { //if topic is null, default topic will be used return new ProducerRecord<>(topic, objectMapper.writeValueAsBytes(message)); } catch (JsonProcessingException e) { throw new IllegalArgumentException("Could not serialize record: " + message, e); } }
Example #3
Source File: PageFunctionCompiler.java From presto with Apache License 2.0 | 5 votes |
@Nullable @Managed @Nested public CacheStatsMBean getProjectionCache() { return projectionCacheStats; }
Example #4
Source File: NumberRangeType.java From mzmine3 with GNU General Public License v2.0 | 5 votes |
/** * A formatted string representation of the value * * @return the formatted representation of the value (or an empty String) */ @Override @Nonnull public String getFormattedString(@Nullable Object value) { if (value instanceof Range) { Range r = (Range) value; return getFormatter().format(r.lowerEndpoint()) + "-" + getFormatter().format(r.upperEndpoint()); } else return ""; }
Example #5
Source File: StringStatistics.java From presto with Apache License 2.0 | 5 votes |
public StringStatistics(@Nullable Slice minimum, @Nullable Slice maximum, long sum) { if (minimum != null && maximum != null && minimum.compareTo(maximum) > 0) { throw new IllegalArgumentException(format( "minimum is not less than or equal to maximum: '%s' [%s], '%s' [%s]", minimum.toStringUtf8(), base16().encode(minimum.getBytes()), maximum.toStringUtf8(), base16().encode(maximum.getBytes()))); } this.minimum = minimum; this.maximum = maximum; this.sum = sum; }
Example #6
Source File: ParallelProcessingTraverserWorker.java From connector-sdk with Apache License 2.0 | 5 votes |
public ParallelProcessingTraverserWorker( TraverserConfiguration conf, IndexingService indexingService, @Nullable ExecutorService executor) { super(conf, indexingService); this.itemRetriever = conf.getItemRetriever(); this.hostload = conf.getHostload(); this.sharedExecutor = executor != null; this.executor = sharedExecutor ? executor : Executors.newCachedThreadPool(); queue = new ConcurrentLinkedQueue<>(); }
Example #7
Source File: AES256GCM.java From incubator-tuweni with Apache License 2.0 | 5 votes |
/** * Decrypt a message using a given key and a detached message authentication code. * * @param cipherText The cipher text to decrypt. * @param mac The message authentication code. * @param data Extra non-confidential data that is included within the encrypted payload. * @param key The key to use for decryption. * @param nonce The nonce that was used for encryption. * @return The decrypted data, or {@code null} if verification failed. * @throws UnsupportedOperationException If AES256-GSM support is not available. */ @Nullable public static byte[] decryptDetached(byte[] cipherText, byte[] mac, byte[] data, Key key, Nonce nonce) { assertAvailable(); checkArgument(!key.isDestroyed(), "Key has been destroyed"); long abytes = Sodium.crypto_aead_aes256gcm_abytes(); if (abytes > Integer.MAX_VALUE) { throw new IllegalStateException("crypto_aead_aes256gcm_abytes: " + abytes + " is too large"); } if (mac.length != abytes) { throw new IllegalArgumentException("mac must be " + abytes + " bytes, got " + mac.length); } byte[] clearText = new byte[cipherText.length]; int rc = Sodium .crypto_aead_aes256gcm_decrypt_detached( clearText, null, cipherText, cipherText.length, mac, data, data.length, nonce.value.pointer(), key.value.pointer()); if (rc == -1) { return null; } if (rc != 0) { throw new SodiumException("crypto_aead_aes256gcm_encrypt: failed with result " + rc); } return clearText; }
Example #8
Source File: TestingDispatcher.java From Flink-CEPplus with Apache License 2.0 | 5 votes |
TestingDispatcher( RpcService rpcService, String endpointId, Configuration configuration, HighAvailabilityServices highAvailabilityServices, GatewayRetriever<ResourceManagerGateway> resourceManagerGatewayRetriever, BlobServer blobServer, HeartbeatServices heartbeatServices, JobManagerMetricGroup jobManagerMetricGroup, @Nullable String metricQueryServicePath, ArchivedExecutionGraphStore archivedExecutionGraphStore, JobManagerRunnerFactory jobManagerRunnerFactory, FatalErrorHandler fatalErrorHandler) throws Exception { super( rpcService, endpointId, configuration, highAvailabilityServices, highAvailabilityServices.getSubmittedJobGraphStore(), resourceManagerGatewayRetriever, blobServer, heartbeatServices, jobManagerMetricGroup, metricQueryServicePath, archivedExecutionGraphStore, jobManagerRunnerFactory, fatalErrorHandler, VoidHistoryServerArchivist.INSTANCE); this.startFuture = new CompletableFuture<>(); }
Example #9
Source File: StoredPaymentChannelClientStates.java From bcm-android with GNU General Public License v3.0 | 5 votes |
/** * Finds a channel with the given id and contract hash and returns it, or returns null. */ @Nullable public StoredClientChannel getChannel(Sha256Hash id, Sha256Hash contractHash) { lock.lock(); try { Set<StoredClientChannel> setChannels = mapChannels.get(id); for (StoredClientChannel channel : setChannels) { if (channel.contract.getHash().equals(contractHash)) return channel; } return null; } finally { lock.unlock(); } }
Example #10
Source File: MixinEntityType.java From patchwork-api with GNU Lesser General Public License v2.1 | 5 votes |
@Inject(method = SPAWN, at = @At(value = "INVOKE", target = "net/minecraft/world/World.spawnEntity(Lnet/minecraft/entity/Entity;)Z"), cancellable = true, locals = LocalCapture.CAPTURE_FAILHARD) private void hookMobSpawns(World world, @Nullable CompoundTag itemTag, @Nullable Text name, @Nullable PlayerEntity player, BlockPos pos, SpawnType type, boolean alignPosition, boolean bl, CallbackInfoReturnable<Entity> callback, Entity entity) { if (!(entity instanceof MobEntity)) { return; } MobEntity mob = (MobEntity) entity; if (EntityEvents.doSpecialSpawn(mob, world, pos.getX(), pos.getY(), pos.getZ(), null, type)) { callback.setReturnValue(null); } }
Example #11
Source File: LongArrayBlockBuilder.java From presto with Apache License 2.0 | 5 votes |
public LongArrayBlockBuilder(@Nullable BlockBuilderStatus blockBuilderStatus, int expectedEntries) { this.blockBuilderStatus = blockBuilderStatus; this.initialEntryCount = max(expectedEntries, 1); updateDataSize(); }
Example #12
Source File: FileUploadHandler.java From Flink-CEPplus with Apache License 2.0 | 5 votes |
private void handleError(ChannelHandlerContext ctx, String errorMessage, HttpResponseStatus responseStatus, @Nullable Throwable e) { HttpRequest tmpRequest = currentHttpRequest; deleteUploadedFiles(); reset(); LOG.warn(errorMessage, e); HandlerUtils.sendErrorResponse( ctx, tmpRequest, new ErrorResponseBody(errorMessage), responseStatus, Collections.emptyMap() ); ReferenceCountUtil.release(tmpRequest); }
Example #13
Source File: ProtobufMessage.java From stateful-functions with Apache License 2.0 | 5 votes |
@Nullable private static Address protobufAddressToSdkAddress(EnvelopeAddress address) { if (address == null || (address.getId().isEmpty() && address.getNamespace().isEmpty() && address.getType().isEmpty())) { return null; } FunctionType functionType = new FunctionType(address.getNamespace(), address.getType()); return new Address(functionType, address.getId()); }
Example #14
Source File: AvroSerializer.java From Flink-CEPplus with Apache License 2.0 | 5 votes |
@SuppressWarnings("unchecked") private void read16Layout(@Nullable String schemaString, ObjectInputStream in) throws IOException, ClassNotFoundException { Schema schema = AvroFactory.parseSchemaString(schemaString); Class<T> type = (Class<T>) in.readObject(); this.previousSchema = new SerializableAvroSchema(); this.schema = new SerializableAvroSchema(schema); this.type = type; }
Example #15
Source File: JobOptimizeRequest.java From kylin-on-parquet-v2 with Apache License 2.0 | 5 votes |
public Set<Long> getCuboidsRecommend() { return Sets.newHashSet(FluentIterable.from(cuboidsRecommend).transform(new Function<String, Long>() { @Nullable @Override public Long apply(@Nullable String cuboid) { return Long.valueOf(cuboid); } })); }
Example #16
Source File: StreamTaskNetworkInput.java From flink with Apache License 2.0 | 5 votes |
@Override @Nullable public StreamElement pollNextNullable() throws Exception { while (true) { // get the stream element from the deserializer if (currentRecordDeserializer != null) { DeserializationResult result = currentRecordDeserializer.getNextRecord(deserializationDelegate); if (result.isBufferConsumed()) { currentRecordDeserializer.getCurrentBuffer().recycleBuffer(); currentRecordDeserializer = null; } if (result.isFullRecord()) { return deserializationDelegate.getInstance(); } } Optional<BufferOrEvent> bufferOrEvent = checkpointedInputGate.pollNext(); if (bufferOrEvent.isPresent()) { processBufferOrEvent(bufferOrEvent.get()); } else { if (checkpointedInputGate.isFinished()) { isFinished = true; checkState(checkpointedInputGate.isAvailable().isDone(), "Finished BarrierHandler should be available"); if (!checkpointedInputGate.isEmpty()) { throw new IllegalStateException("Trailing data in checkpoint barrier handler."); } } return null; } } }
Example #17
Source File: ArchivedExecutionGraph.java From flink with Apache License 2.0 | 5 votes |
public ArchivedExecutionGraph( JobID jobID, String jobName, Map<JobVertexID, ArchivedExecutionJobVertex> tasks, List<ArchivedExecutionJobVertex> verticesInCreationOrder, long[] stateTimestamps, JobStatus state, @Nullable ErrorInfo failureCause, String jsonPlan, StringifiedAccumulatorResult[] archivedUserAccumulators, Map<String, SerializedValue<OptionalFailure<Object>>> serializedUserAccumulators, ArchivedExecutionConfig executionConfig, boolean isStoppable, @Nullable CheckpointCoordinatorConfiguration jobCheckpointingConfiguration, @Nullable CheckpointStatsSnapshot checkpointStatsSnapshot) { this.jobID = Preconditions.checkNotNull(jobID); this.jobName = Preconditions.checkNotNull(jobName); this.tasks = Preconditions.checkNotNull(tasks); this.verticesInCreationOrder = Preconditions.checkNotNull(verticesInCreationOrder); this.stateTimestamps = Preconditions.checkNotNull(stateTimestamps); this.state = Preconditions.checkNotNull(state); this.failureCause = failureCause; this.jsonPlan = Preconditions.checkNotNull(jsonPlan); this.archivedUserAccumulators = Preconditions.checkNotNull(archivedUserAccumulators); this.serializedUserAccumulators = Preconditions.checkNotNull(serializedUserAccumulators); this.archivedExecutionConfig = Preconditions.checkNotNull(executionConfig); this.isStoppable = isStoppable; this.jobCheckpointingConfiguration = jobCheckpointingConfiguration; this.checkpointStatsSnapshot = checkpointStatsSnapshot; }
Example #18
Source File: StateTableKeyGroupPartitionerTest.java From Flink-CEPplus with Apache License 2.0 | 5 votes |
private static StateTableEntry<Integer, VoidNamespace, Integer> generateElement( @Nonnull Random random, @Nullable StateTableEntry<Integer, VoidNamespace, Integer> next) { Integer generatedKey = random.nextInt() & Integer.MAX_VALUE; return new StateTableEntry<>( generatedKey, VoidNamespace.INSTANCE, random.nextInt(), generatedKey.hashCode(), next, 0, 0); }
Example #19
Source File: PosMethod.java From supl-client with Apache License 2.0 | 4 votes |
@Override @Nullable protected Asn1Tag getTag() { return TAG_PosMethod; }
Example #20
Source File: SETAuthKey.java From supl-client with Apache License 2.0 | 4 votes |
@Override @Nullable public Asn1Tag getTag() { return tag; }
Example #21
Source File: EllipsoidPointWithAltitude.java From supl-client with Apache License 2.0 | 4 votes |
@Override @Nullable protected Asn1Tag getTag() { return TAG_latitudeSignType; }
Example #22
Source File: ProximityGoal.java From PGM with GNU Affero General Public License v3.0 | 4 votes |
public boolean shouldShowProximity(@Nullable Competitor team, Party viewer) { return team != null && PGM.get().getConfiguration().showProximity() && isProximityRelevant(team) && (viewer == team || viewer.isObserving()); }
Example #23
Source File: GNSS_ClockModel.java From supl-client with Apache License 2.0 | 4 votes |
@Nullable @Override protected ChoiceComponent getSelectedComponent() { return selection; }
Example #24
Source File: GPSDeltaEpochHeader.java From supl-client with Apache License 2.0 | 4 votes |
@Override @Nullable protected Asn1Tag getTag() { return TAG_GPSDeltaEpochHeader; }
Example #25
Source File: SessionCapabilities.java From supl-client with Apache License 2.0 | 4 votes |
@Override @Nullable protected Asn1Tag getTag() { return TAG_maxNumberTotalSessionsType; }
Example #26
Source File: Almanac_NAVKeplerianSet.java From supl-client with Apache License 2.0 | 4 votes |
@Override @Nullable protected Asn1Tag getTag() { return TAG_navAlmOmegaType; }
Example #27
Source File: TBS_RequestCapabilities_r13.java From supl-client with Apache License 2.0 | 4 votes |
@Override @Nullable protected Asn1Tag getTag() { return TAG_TBS_RequestCapabilities_r13; }
Example #28
Source File: SharedSlot.java From Flink-CEPplus with Apache License 2.0 | 4 votes |
/** * Creates a new shared slot that has is a sub-slot of the given parent shared slot, and that belongs * to the given task group. * * @param owner The component from which this slot is allocated. * @param location The location info of the TaskManager where the slot was allocated from * @param slotNumber The number of the slot. * @param taskManagerGateway The gateway to communicate with the TaskManager * @param assignmentGroup The assignment group that this shared slot belongs to. * @param parent The parent slot of this slot. * @param groupId The assignment group of this slot. */ public SharedSlot( SlotOwner owner, TaskManagerLocation location, int slotNumber, TaskManagerGateway taskManagerGateway, SlotSharingGroupAssignment assignmentGroup, @Nullable SharedSlot parent, @Nullable AbstractID groupId) { super(owner, location, slotNumber, taskManagerGateway, parent, groupId); this.assignmentGroup = checkNotNull(assignmentGroup); this.subSlots = new HashSet<Slot>(); }
Example #29
Source File: Grib1Customizer.java From netcdf-java with BSD 3-Clause "New" or "Revised" License | 4 votes |
@Nullable protected synchronized Map<Integer, VertCoordType> readTable3(String path) { try (InputStream is = GribResourceReader.getInputStream(path)) { SAXBuilder builder = new SAXBuilder(); org.jdom2.Document doc = builder.build(is); Element root = doc.getRootElement(); Map<Integer, VertCoordType> result = new HashMap<>(200); List<Element> params = root.getChildren("parameter"); for (Element elem1 : params) { int code = Integer.parseInt(elem1.getAttributeValue("code")); String desc = elem1.getChildText("description"); String abbrev = elem1.getChildText("abbrev"); String units = elem1.getChildText("units"); String datum = elem1.getChildText("datum"); boolean isLayer = elem1.getChild("isLayer") != null; boolean isPositiveUp = elem1.getChild("isPositiveUp") != null; VertCoordType lt = new VertCoordType(code, desc, abbrev, units, datum, isPositiveUp, isLayer); result.put(code, lt); } return Collections.unmodifiableMap(result); // all at once - thread safe } catch (IOException | JDOMException e) { logger.error("Cant parse NcepLevelTypes = " + path, e); return null; } }
Example #30
Source File: SupportedWLANApsChannel11bg.java From supl-client with Apache License 2.0 | 4 votes |
@Override @Nullable protected Asn1Tag getTag() { return TAG_ch5Type; }