-
EDU.oswego.cs.dl.util.concurrent.SynchronizedInt.increment()
Increment the value.
@return the new value
-
aima.core.util.math.MixedRadixNumber.increment()
Increments the value of the mixed radix number, if the value is less than the maximum value which can be represented by the current array of radices.
@return true
if the increment was successful.
-
bm.core.event.ProgressEvent.increment()
-
co.cask.cdap.common.metrics.MetricsCollector.increment()
Log a metric value at the current time.
@param metricName Name of the metric.
@param value value of the metric.
@param tags Tags associated with the metric.
-
com.aliasi.classify.ConfusionMatrix.increment()
-
com.apress.prospring.ch13.ejb.CounterService.increment()
-
com.avaje.ebeaninternal.server.util.LongAdder.increment()
Equivalent to {@code add(1)}.
-
com.barrybecker4.common.geometry.MutableIntLocation.increment()
-
com.cetsoft.caudit.quantity.LongQuantity.increment()
Increment.
-
com.example.Counter.increment()
-
com.google.appengine.api.memcache.MemcacheService.increment()
Atomically fetches, increments, and stores a given integral value. "Integral" types are {@link Byte}, {@link Short}, {@link Integer}, {@link Long}, and in some cases {@link String}. The entry must already exist, and have a non-negative value.
Incrementing by positive amounts will reach signed 64-bit max ( {@code 2^63 - 1}) and then wrap-around to signed 64-bit min ( {@code -2^63}), continuing increments from that point.
To facilitate use as an atomic countdown, incrementing by a negative value (i.e. decrementing) will not go below zero: incrementing {@code 2} by{@code -5} will return {@code 0}, not {@code -3}.
Note: The actual representation of all numbers in Memcache is a string. This means if you initially stored a number as a string (e.g., "10") and then increment it, everything will work properly.
When you {@link #get(Object)} a key for a string value, wrapping occursafter exceeding the max value of an unsigned 64-bit number ( {@code 2^64 - 1}). When you {@link #get(Object)} a keyfor a numerical type, wrapping occurs after exceeding the type max value.
@param key the key of the entry to manipulate
@param delta the size of the increment, positive or negative
@return the post-increment value, as a long. However, a{@link #get(Object)} of the key will still have the original type ({@link Byte}, {@link Short}, etc.). If there is no entry for {@code key}, returns {@code null}.
@throws IllegalArgumentException if {@code key} is not{@link Serializable} and is not {@code null}
@throws InvalidValueException if the object incremented is not of aintegral type or holding a negative value
-
com.gs.collections.impl.Counter.increment()
-
com.mchange.v2.holders.SynchronizedIntHolder.increment()
-
com.metamx.common.Granularity.increment()
-
com.netflix.curator.framework.recipes.atomic.DistributedAtomicLong.increment()
-
com.netflix.servo.monitor.BasicCounter.increment()
{@inheritDoc}
-
com.netflix.servo.monitor.StepCounter.increment()
{@inheritDoc}
-
com.openkm.kea.util.Counter.increment()
-
com.orientechnologies.common.types.OModifiableInteger.increment()
-
com.orientechnologies.orient.core.version.ORecordVersion.increment()
-
com.prodeagle.java.counters.BatchCounter.increment()
Increment a named counter in a batch by 1
@param name - the name of the counter to increment by 1
-
com.proofpoint.testing.TestingTicker.increment()
-
com.scaleunlimited.cascading.LoggingFlowProcess.increment()
-
com.sleepycat.je.utilint.IntStat.increment()
-
com.strobel.core.MutableInteger.increment()
-
com.subhajit.common.util.IProgress.increment()
-
com.subhajit.eclipse.swt.SwtProgressImpl.increment()
-
com.sun.sgs.test.impl.service.task.TestTaskServiceImpl.Counter.increment()
-
com.volantis.xml.expression.PositionScope.increment()
Permits the position value to be incremented by one on each invocation.
-
edu.umd.cloud9.io.map.HMapSFW.increment()
Increments the key. If the key does not exist in the map, its value is set to one.
@param key key to increment
-
edu.umd.cloud9.io.map.HMapSIW.increment()
Increments the key. If the key does not exist in the map, its value is set to one.
@param key key to increment
-
edu.umd.cloud9.io.map.Int2FloatOpenHashMapWritable.increment()
Increments the key. If the key does not exist in the map, its value is set to one.
@param key key to increment
-
edu.umd.cloud9.io.map.Int2IntOpenHashMapWritable.increment()
Increments the key. If the key does not exist in the map, its value is set to one.
@param key key to increment
-
edu.umd.cloud9.io.map.String2IntOpenHashMapWritable.increment()
Increments the key. If the key does not exist in the map, its value is set to one.
@param key key to increment
-
edu.umd.cloud9.util.fd.Int2IntFrequencyDistribution.increment()
Increments the count of an event {@code key}.
-
edu.umd.cloud9.util.fd.Int2IntFrequencyDistributionEntry.increment()
-
edu.umd.cloud9.util.fd.Int2IntFrequencyDistributionFastutil.increment()
-
edu.umd.cloud9.util.map.HMapID.increment()
Increments the key by some value. If the key does not exist in the map, its value is set to the parameter value.
@param key key to increment
@param value increment value
-
edu.umd.cloud9.util.map.HMapIF.increment()
Increments the key by some value. If the key does not exist in the map, its value is set to the parameter value.
@param key key to increment
@param value increment value
-
edu.umd.cloud9.util.map.HMapII.increment()
Increments the key. If the key does not exist in the map, its value is set to one.
@param key key to increment
-
edu.umd.cloud9.util.map.HMapIL.increment()
Increments the key. If the key does not exist in the map, its value is set to one.
@param key key to increment
-
edu.umd.cloud9.util.map.HMapIS.increment()
Increments the key. If the key does not exist in the map, its value is set to one.
@param key key to increment
-
er.extensions.foundation.ERXMutableInteger.increment()
Increments the int value of this ERXMutalbleInteger
object by 1.
-
flexjson.TypeContext.increment()
-
gnu.trove.map.TIntLongMap.increment()
Increments the primitive value mapped to key by 1
@param key the key of the value to increment
@return true if a mapping was found and modified.
-
httl.util.Status.increment()
-
io.airlift.testing.TestingTicker.increment()
-
io.druid.query.aggregation.TestFloatColumnSelector.increment()
-
io.druid.segment.data.Offset.increment()
-
io.fabric8.utils.CountingMap.increment()
Increments the given key
-
java.util.concurrent.atomic.LongAdder.increment()
Equivalent to {@code add(1)}.
-
kea.util.Counter.increment()
-
maui.util.Counter.increment()
Increments the counter.
-
net.floodlightcontroller.counter.ICounter.increment()
Most commonly used method
-
net.floodlightcontroller.counter.SimpleCounter.increment()
This is the key method that has to be both fast and very thread-safe.
-
net.kuujo.vertigo.cluster.data.AsyncCounter.increment()
Increments the counter value.
-
net.myrrix.common.collection.FastByIDFloatMap.increment()
-
net.myrrix.common.stats.DoubleWeightedMean.increment()
-
net.sf.joafip.entity.MutableInteger.increment()
-
opennlp.maxent.Counter.increment()
-
org.apache.activemq.broker.ProgressPrinter.increment()
-
org.apache.activemq.management.CountStatisticImpl.increment()
-
org.apache.camel.util.concurrent.CountingLatch.increment()
Increment the count with 1
-
org.apache.commons.lang.mutable.MutableInt.increment()
Increments the value.
@since Commons Lang 2.2
-
org.apache.commons.lang.mutable.MutableLong.increment()
Increments the value.
@since Commons Lang 2.2
-
org.apache.commons.lang3.mutable.MutableInt.increment()
Increments the value.
@since Commons Lang 2.2
-
org.apache.commons.lang3.mutable.MutableLong.increment()
Increments the value.
@since Commons Lang 2.2
-
org.apache.commons.math.stat.descriptive.StorelessUnivariateStatistic.increment()
Updates the internal state of the statistic to reflect the addition of the new value.
@param d the new value.
-
org.apache.commons.math.stat.descriptive.moment.FourthMoment.increment()
{@inheritDoc}
-
org.apache.commons.math.stat.descriptive.moment.Mean.increment()
{@inheritDoc}
-
org.apache.commons.math.stat.descriptive.moment.SecondMoment.increment()
{@inheritDoc}
-
org.apache.commons.math.stat.descriptive.moment.StandardDeviation.increment()
{@inheritDoc}
-
org.apache.commons.math.stat.descriptive.moment.VectorialCovariance.increment()
Add a new vector to the sample.
@param v vector to add
@exception DimensionMismatchException if the vector does not have the right dimension
-
org.apache.commons.math.stat.descriptive.moment.VectorialMean.increment()
Add a new vector to the sample.
@param v vector to add
@exception DimensionMismatchException if the vector does not have the right dimension
-
org.apache.commons.math.stat.descriptive.summary.Sum.increment()
{@inheritDoc}
-
org.apache.commons.math.stat.descriptive.summary.SumOfSquares.increment()
{@inheritDoc}
-
org.apache.commons.math.stat.univariate.moment.FourthMoment.increment()
@see org.apache.commons.math.stat.univariate.StorelessUnivariateStatistic#increment(double)
-
org.apache.commons.math.stat.univariate.moment.Kurtosis.increment()
@see org.apache.commons.math.stat.univariate.StorelessUnivariateStatistic#increment(double)
-
org.apache.commons.math.stat.univariate.moment.Mean.increment()
@see org.apache.commons.math.stat.univariate.StorelessUnivariateStatistic#increment(double)
-
org.apache.commons.math.stat.univariate.moment.Skewness.increment()
@see org.apache.commons.math.stat.univariate.StorelessUnivariateStatistic#increment(double)
-
org.apache.commons.math.stat.univariate.moment.Variance.increment()
@see org.apache.commons.math.stat.univariate.StorelessUnivariateStatistic#increment(double)
-
org.apache.commons.math3.stat.correlation.StorelessCovariance.increment()
Increment the covariance matrix with one row of data.
@param data array representing one row of data.
@throws DimensionMismatchException if the length of rowData
does not match with the covariance matrix
-
org.apache.commons.math3.stat.descriptive.moment.Mean.increment()
{@inheritDoc}
Note that when {@link #Mean(FirstMoment)} is used tocreate a Mean, this method does nothing. In that case, the FirstMoment should be incremented directly.
-
org.apache.commons.math3.stat.descriptive.moment.SecondMoment.increment()
{@inheritDoc}
-
org.apache.commons.math3.stat.descriptive.moment.Skewness.increment()
{@inheritDoc}
Note that when {@link #Skewness(ThirdMoment)} is used tocreate a Skewness, this method does nothing. In that case, the ThirdMoment should be incremented directly.
-
org.apache.commons.math3.stat.descriptive.moment.StandardDeviation.increment()
{@inheritDoc}
-
org.apache.commons.math3.stat.descriptive.moment.Variance.increment()
{@inheritDoc}
If all values are available, it is more accurate to use {@link #evaluate(double[])} rather than adding values one at a timeusing this method and then executing {@link #getResult}, since evaluate
leverages the fact that is has the full list of values together to execute a two-pass algorithm. See {@link Variance}.
Note also that when {@link #Variance(SecondMoment)} is used tocreate a Variance, this method does nothing. In that case, the SecondMoment should be incremented directly.
-
org.apache.commons.math3.stat.descriptive.moment.VectorialCovariance.increment()
Add a new vector to the sample.
@param v vector to add
@throws DimensionMismatchException if the vector does not have the right dimension
-
org.apache.commons.math3.stat.descriptive.moment.VectorialMean.increment()
Add a new vector to the sample.
@param v vector to add
@throws DimensionMismatchException if the vector does not have the right dimension
-
org.apache.commons.math3.stat.descriptive.rank.Max.increment()
{@inheritDoc}
-
org.apache.commons.math3.stat.descriptive.rank.Min.increment()
{@inheritDoc}
-
org.apache.commons.math3.stat.descriptive.summary.Sum.increment()
{@inheritDoc}
-
org.apache.commons.math3.stat.descriptive.summary.SumOfLogs.increment()
{@inheritDoc}
-
org.apache.commons.math3.stat.descriptive.summary.SumOfSquares.increment()
{@inheritDoc}
-
org.apache.curator.framework.recipes.atomic.DistributedAtomicInteger.increment()
Add 1 to the current value and return the new value information. Remember to always check {@link AtomicValue#succeeded()}.
@return value info
@throws Exception ZooKeeper errors
-
org.apache.directory.server.core.api.SearchRequestContainer.increment()
@param count the count to set
-
org.apache.excalibur.instrument.CounterInstrument.increment()
Increments the Instrument. This method is optimized to be extremely light weight when an InstrumentManager is not present and there are no registered CounterInstrumentListeners.
-
org.apache.excalibur.instrument.manager.CounterInstrumentListener.increment()
Called by a CounterInstrument whenever its value is incremented.
@param instrumentName The name of Instrument which was incremented.
@param count A positive integer to increment the counter by.
@param time The time that the Instrument was incremented.
-
org.apache.hadoop.hbase.client.HTable.increment()
{@inheritDoc}
-
org.apache.hadoop.hbase.client.HTableInterface.increment()
Increments one or more columns within a single row.
This operation does not appear atomic to readers. Increments are done under a single row lock, so write operations to a row are synchronized, but readers do not take row locks so get and scan operations can see this operation partially completed.
@param increment object that specifies the columns and amounts to be usedfor the increment operations
@throws IOException e
@return values of columns after the increment
-
org.apache.hadoop.hbase.client.Table.increment()
Increments one or more columns within a single row.
This operation does not appear atomic to readers. Increments are done under a single row lock, so write operations to a row are synchronized, but readers do not take row locks so get and scan operations can see this operation partially completed.
@param increment object that specifies the columns and amounts to be usedfor the increment operations
@throws IOException e
@return values of columns after the increment
-
org.apache.hadoop.hbase.regionserver.HRegion.increment()
Perform one or more increment operations on a row.
Increments performed are done under row lock but reads do not take locks out so this can be seen partially complete by gets and scans.
@param increment
@param writeToWAL
@return new keyvalues after increment
@throws IOException
-
org.apache.hadoop.hdfs.server.namenode.startupprogress.StartupProgress.Counter.increment()
-
org.apache.hadoop.mapred.Counters.Counter.increment()
-
org.apache.hadoop.mapreduce.Counter.increment()
Increment this counter by the given value
@param incr the value to increase this counter by
-
org.apache.jackrabbit.oak.plugins.document.UpdateOp.increment()
Increment the value.
@param property the key
@param value the increment
-
org.apache.oozie.util.TimestampedMessageParser.increment()
Causes the next message and timestamp to be parsed from the BufferedReader.
@return true if there are more messages left; false if not
@throws IOException If there was a problem reading from the Reader
-
org.apache.servicemix.nmr.management.stats.CountStatistic.increment()
-
org.apache.tez.common.counters.TezCounter.increment()
Increment this counter by the given value
@param incr the value to increase this counter by
-
org.apache.uima.aae.monitor.statistics.LongNumericStatistic.increment()
-
org.apache.wicket.util.value.Count.increment()
Increases the count
-
org.apache.yaoql.util.Counter.increment()
-
org.cliffc.high_scale_lib.Counter.increment()
-
org.eclipse.orion.server.core.resources.Base64Counter.increment()
Increments the counter by one.
-
org.groovymud.utils.CountingMap.increment()
-
org.hibernate.id.IntegralDataTypeHolder.increment()
Equivalent to a ++ operation
@return this, for method chaining
-
org.hornetq.core.paging.PageTransactionInfo.increment()
-
org.hornetq.core.paging.cursor.PageSubscriptionCounter.increment()
-
org.hornetq.core.paging.impl.PageTransactionInfoImpl.increment()
-
org.integratedmodelling.riskwiz.learning.dtable.Dirichlet.increment()
-
org.jacoco.core.analysis.LinesImpl.increment()
Adds the given lines as fully covered or not covered.
@param lines line numbers to add
@param covered true
if all lines are covered
-
org.jacoco.core.internal.analysis.MethodCoverageImpl.increment()
-
org.jacoco.core.internal.analysis.SourceFileCoverageImpl.increment()
-
org.jacoco.core.internal.analysis.SourceNodeImpl.increment()
Increments all counters by the values of the given child. When incrementing the line counter is is assumed that the child refers to the same source file.
@param child child node to add
-
org.jboss.as.demos.ejb3.archive.SimpleSingletonLocal.increment()
-
org.jboss.as.jpa.config.PersistenceUnitCount.increment()
-
org.jboss.as.jpa.config.PersistenceUnitsInApplication.increment()
Increment the count of persistence units in application
@param incrementValue
-
org.jboss.as.quickstarts.ejb.remote.stateful.RemoteCounter.increment()
-
org.jboss.as.test.clustering.cluster.ejb.remote.bean.Incrementor.increment()
-
org.jboss.as.test.clustering.cluster.ejb.stateful.bean.Incrementor.increment()
-
org.jboss.as.test.clustering.cluster.ejb3.deployment.ClusteredBean.increment()
-
org.jboss.as.test.clustering.cluster.ejb3.deployment.DDBasedClusteredBean.increment()
-
org.jboss.as.test.clustering.cluster.ejb3.stateful.remote.failover.RemoteCounter.increment()
-
org.jboss.cache.optimistic.DefaultDataVersion.increment()
Returns a new DataVersion with a newer version number.
-
org.jboss.messaging.core.impl.DeliveringCounter.increment()
-
org.jboss.test.cluster.ejb3.clusteredsession.StatefulRemote.increment()
-
org.jboss.test.cluster.ejb3.stateful.nested.base.std.NestedStateful.increment()
-
org.jboss.test.cluster.ejb3.stateful.nested.base.std.ParentStatefulRemote.increment()
-
org.jboss.test.ejb3.war.deployment.Counter.increment()
-
org.jdk8.backport.LongAdder.increment()
Equivalent to {@code add(1)}.
-
org.jquantlib.util.Date.increment()
Increments the date by one day
@return this
Date incremented
-
org.kiji.schema.KijiTableWriter.increment()
-
org.mizartools.dli.utility.SchemeId.increment()
-
org.mizartools.dli.utility.TheoremId.increment()
-
org.neo4j.shell.tools.imp.util.BatchTransaction.increment()
-
org.odlabs.wiquery.ui.progressbar.ProgressBar.increment()
Method to increment the value of the progressBar
@return the associated JsStatement
-
org.ow2.util.auditreport.api.IAuditID.increment()
Increment the counter.
-
org.owasp.webscarab.plugin.fuzz.FuzzSource.increment()
-
org.qi4j.api.metrics.MetricsCounter.increment()
-
org.rioproject.impl.watch.CounterWatch.increment()
@see CounterWatchMBean#increment()
-
org.rioproject.opstring.OperationalStringManager.increment()
Increment (increase) the number of instances by one. This will cause the provisioning of a ServiceBean to an available compute resource which meets the operational criteria specified by the ServiceElement. If the increment request cannot be accomplished (no available compute resources that meet operational requirements of the service), and the {@link org.rioproject.deploy.ServiceProvisionListener} parameter is not null,the {@link org.rioproject.deploy.ServiceProvisionListener} will be notified ofthe result. Additionally if the increment request cannot be carried out, the request will be submitted for future processing
@param sElem The ServiceElement instance to increment. This parameteris used to match a ServiceElement being managed by the {@code OperationalStringManager}
@param permanent If the increment request should be considered permanent. If set to false, the number of service instances may vary over time
@param listener If not null, the ServiceProvisionListener will benotified on the result of the attempt to increment the amount of service instances.
@throws OperationalStringException If the ServiceElement is not beingmanaged by the {@code OperationalStringManager} (or the {@code OperationalStringManager}is not the managing {@code OperationalStringManager} for the OperationalString)
@throws RemoteException If communication errors occur
-
org.springframework.batch.repeat.context.RepeatContextCounter.increment()
Increment the counter.
@param delta the amount by which to increment the counter.
-
org.springframework.osgi.extender.internal.util.concurrent.Counter.increment()
Increment the counter value.
-
org.springframework.xd.analytics.metrics.core.Counter.increment()
Increment this counter by a given amount. Stores that manage their own value bookkeepingmay not use this method.
-
org.wso2.carbon.bam.data.publisher.activity.service.Counter.increment()
-
org.wso2.carbon.bam.data.publisher.clientstats.Counter.increment()
-
org.wso2.carbon.registry.core.statistics.query.StatisticsRecord.increment()
Increments the nested depth of the transaction.
@return current depth.
-
org.zanata.rest.dto.stats.TranslationStatistics.increment()
-
org.zanata.ui.model.statistic.WordStatistic.increment()
-
react.IntValue.increment()
-
se.unlogic.standardutils.numbers.IntegerCounter.increment()