-
at.jku.sii.sqlitereader.io.ArrayDataInput.readInt()
-
at.jku.sii.sqlitereader.io.FileDataInput.readInt()
-
bm.core.io.SerializerInputStream.readInt()
-
cmp.LEDataStream.LEDataInputStream.readInt()
like DataInputStream.readInt except little endian.
-
co.cask.cdap.common.io.BinaryDecoder.readInt()
-
co.cask.cdap.common.io.Decoder.readInt()
-
co.cask.tigon.io.BinaryDecoder.readInt()
-
com.alibaba.dubbo.common.serialize.ObjectInput.readInt()
-
com.android.dex.Dex.Section.readInt()
-
com.ardor3d.util.LittleEndianDataInput.readInt()
-
com.ardor3d.util.LittleEndianRandomAccessDataInput.readInt()
-
com.badlogic.gdx.utils.DataInput.readInt()
-
com.caucho.hessian.io.Hessian2Input.readInt()
Reads an integer
I b32 b24 b16 b8
-
com.esotericsoftware.kryo.io.ByteBufferInput.readInt()
-
com.esotericsoftware.kryo.io.Input.readInt()
Reads a 4 byte int.
-
com.esotericsoftware.kryo.io.InputChunked.readInt()
-
com.esotericsoftware.kryo.io.UnsafeInput.readInt()
Reads a 4 byte int.
-
com.esotericsoftware.kryo.io.UnsafeMemoryInput.readInt()
Reads a 4 byte int.
-
com.eviware.soapui.support.xml.XmlObjectConfigurationReader.readInt()
-
com.firefly.utils.json.JsonReader.readInt()
-
com.firefly.utils.json.io.JsonStringReader.readInt()
-
com.google.code.or.io.XInputStream.readInt()
-
com.google.code.or.io.util.XDeserializer.readInt()
-
com.google.common.io.ByteArrayDataInput.readInt()
-
com.google.common.io.LittleEndianDataInputStream.readInt()
Reads an integer as specified by {@link DataInputStream#readInt()}, except using little-endian byte order.
@return the next four bytes of the input stream, interpreted as an {@code int} in little-endian byte order
@throws IOException if an I/O error occurs
-
com.google.gwt.user.client.rpc.SerializationStreamReader.readInt()
-
com.google.gwt.user.server.rpc.impl.ServerSerializationStreamReader.readInt()
-
com.hazelcast.nio.BufferObjectDataInput.readInt()
-
com.hazelcast.nio.ObjectDataInput.readInt()
-
com.hazelcast.nio.serialization.ObjectDataInputStream.readInt()
-
com.hazelcast.nio.serialization.PortableReader.readInt()
-
com.higherfrequencytrading.chronicle.Excerpt.readInt()
-
com.itextpdf.text.pdf.codec.wmf.InputMeta.readInt()
-
com.jme.util.export.InputCapsule.readInt()
-
com.jme3.export.InputCapsule.readInt()
-
com.jme3.scene.plugins.blender.file.BlenderInputStream.readInt()
This method reads 4-byte number from the stream.
@return a number from the stream (4 bytes read)
-
com.jme3.util.LittleEndien.readInt()
-
com.lightcrafts.utils.file.OrderableRandomAccessFile.readInt()
-
com.lowagie.text.pdf.codec.wmf.InputMeta.readInt()
-
com.maverick.util.ByteArrayReader.readInt()
Read an integer (4 bytes) from the array. This is returned as a long as we deal with unsigned ints so the value may be higher than the standard java int.
@param data
@param start
@return the value represent by a long.
-
com.mobixess.jodb.core.io.IRandomAccessDataBuffer.readInt()
-
com.orientechnologies.orient.core.storage.fs.OFile.readInt()
-
com.orientechnologies.orient.enterprise.channel.binary.OChannelBinaryAsynchClient.readInt()
-
com.orientechnologies.orient.enterprise.channel.binary.OChannelBinaryClient.readInt()
-
com.peterhi.obsolete.Stream.readInt()
-
com.sleepycat.bind.tuple.TupleInput.readInt()
Reads a signed int (four byte) value from the buffer. Reads values that were written using {@link TupleOutput#writeInt}.
@return the value read from the buffer.
@throws IndexOutOfBoundsException if not enough bytes are available inthe buffer.
@see
Integer Formats
-
com.sshtools.j2ssh.io.ByteArrayReader.readInt()
@param data
@param start
@return
-
com.sun.enterprise.naming.util.ObjectInputStreamWithLoader.readInt()
-
com.sun.messaging.jmq.io.VRecordRAF.readInt()
-
com.vividsolutions.jts.io.ByteOrderDataInStream.readInt()
-
davaguine.jmac.tools.ByteArrayReader.readInt()
-
de.hpi.eworld.visualizer.simulation.traci.common.TraciInputStream.readInt()
-
de.uniluebeck.itm.tcpip.Storage.readInt()
Read a signed integer value, that was split up into 4 bytes
@return the read int value
-
edu.stanford.nlp.io.InDataStreamFile.readInt()
-
es.upv.simulator.Tokenizer.readInt()
-
eu.stratosphere.runtime.io.serialization.DataInputDeserializer.readInt()
-
fr.dyade.aaa.jndi2.msg.IOControl.readInt()
-
hprose.io.HproseReader.readInt()
-
htsjdk.tribble.util.LittleEndianInputStream.readInt()
-
info.ata4.io.DataInputReader.readInt()
-
io.airlift.slice.SliceInput.readInt()
Gets a 32-bit integer at the current {@code position}and increases the {@code position} by {@code 4} in this buffer.
@throws IndexOutOfBoundsException if {@code this.available()} is less than {@code 4}
-
io.netty.buffer.ByteBuf.readInt()
Gets a 32-bit integer at the current {@code readerIndex}and increases the {@code readerIndex} by {@code 4} in this buffer.
@throws IndexOutOfBoundsException if {@code this.readableBytes} is less than {@code 4}
-
java.io.BufferedInputStream.readInt()
-
java.io.DataInputStream.readInt()
See the general contract of the
readInt
method of
DataInput
.
Bytes for this operation are read from the contained input stream.
@return the next four bytes of this input stream, interpreted as anint
.
@exception EOFException if this input stream reaches the end beforereading four bytes.
@exception IOException the stream has been closed and the containedinput stream does not support reading after close, or another I/O error occurs.
@see java.io.FilterInputStream#in
-
java.io.ObjectInput.readInt()
-
java.io.ObjectInputStream.readInt()
Reads and returns primitive data of type int read from the receiver
@return an int saved as primitive data usingObjectOutputStream.writeInt()
@throws IOException If an IO exception happened when reading the primitive data.
-
java.io.RandomAccessFile.readInt()
Reads a 32-bit integer value from this stream.
@return int the next int
value from the source stream.
@throws IOException If a problem occurs reading from this DataInputStream.
@see DataOutput#writeInt(int)
-
javax.imageio.stream.ImageInputStream.readInt()
Reads 4 bytes from the stream, and (conceptually) concatenates them according to the current byte order and returns the result as an
int
.
The bit offset within the stream is ignored and treated as though it were zero.
@return a signed int value from the stream.
@exception java.io.EOFException if the stream reaches the end beforereading all the bytes.
@exception IOException if an I/O error occurs.
@see #getByteOrder
-
javax.imageio.stream.ImageInputStreamImplTest.BasicImageInputStreamImpl.readInt()
-
javax.imageio.stream.MemoryCacheImageInputStream.readInt()
-
javax.jms.BytesMessage.readInt()
-
javax.jms.StreamMessage.readInt()
-
javax.sql.rowset.serial.SQLInputImpl.readInt()
Retrieves the next attribute in this
SQLInputImpl
object as an
int
in the Java programming language.
This method does not perform type-safe checking to determine if the returned type is the expected type; this responsibility is delegated to the UDT mapping as defined by a SQLData
implementation.
@return the next attribute in this SQLInputImpl
object;if the value is SQL NULL
, return null
@throws SQLException if the read position is located at an invalidposition or if there are no more values in the stream
-
krati.core.segment.Segment.readInt()
Reads an integer value from the specified position.
@param pos - the position (i.e. offset) in segment
@return an integer value
@throws IOException
-
krati.io.ChannelReader.readInt()
-
krati.io.DataReader.readInt()
-
loci.common.IRandomAccess.readInt()
-
loci.common.RandomAccessInputStream.readInt()
-
marauroa.common.net.InputSerializer.readInt()
This method reads a int from the Serializer
@return the int serialized
@throws java.io.IOException if there is an IO error
-
net.minecraft.network.PacketBuffer.readInt()
-
net.sf.agentopia.platform.IAgentopiaConnection.readInt()
Reads an int from the other side.
@return An int.
@exception IOException If network access failed.
-
net.timewalker.ffmq3.common.message.BytesMessageImpl.readInt()
-
net.timewalker.ffmq3.common.message.StreamMessageImpl.readInt()
-
net.tomp2p.storage.AlternativeCompositeByteBuf.readInt()
-
net.yura.lobby.util.ByteBufferInputStream.readInt()
-
nom.tam.util.BufferedDataInputStream.readInt()
-
org.activeio.PacketData.readInt()
-
org.activemq.message.ActiveMQBytesMessage.readInt()
Reads a signed 32-bit integer from the bytes message stream.
@return the next four bytes from the bytes message stream, interpreted as an int
@throws JMSException if the JMS provider fails to read the message due to some internal error.
@throws MessageEOFException if unexpected end of bytes stream has been reached.
@throws MessageNotReadableException if the message is in write-only mode.
-
org.activemq.message.ActiveMQStreamMessage.readInt()
Reads a 32-bit integer from the stream message.
@return a 32-bit integer value from the stream message, interpretedas an int
@throws JMSException if the JMS provider fails to read the messagedue to some internal error.
@throws MessageEOFException if unexpected end of message stream hasbeen reached.
@throws MessageFormatException if this type conversion is invalid.
@throws MessageNotReadableException if the message is in write-onlymode.
-
org.agilewiki.jid.ReadableBytes.readInt()
Read an int.
@return The it that was read.
-
org.apache.accumulo.core.file.blockfile.ABlockReader.readInt()
-
org.apache.activeio.packet.PacketData.readInt()
-
org.apache.activemq.command.ActiveMQBytesMessage.readInt()
Reads a signed 32-bit integer from the bytes message stream.
@return the next four bytes from the bytes message stream, interpreted asan int
@throws JMSException if the JMS provider fails to read the message due tosome internal error.
@throws MessageEOFException if unexpected end of bytes stream has beenreached.
@throws MessageNotReadableException if the message is in write-only mode.
-
org.apache.activemq.command.ActiveMQStreamMessage.readInt()
Reads a 32-bit integer from the stream message.
@return a 32-bit integer value from the stream message, interpreted as anint
@throws JMSException if the JMS provider fails to read the message due tosome internal error.
@throws MessageEOFException if unexpected end of message stream has beenreached.
@throws MessageFormatException if this type conversion is invalid.
@throws MessageNotReadableException if the message is in write-only mode.
-
org.apache.activemq.util.DataByteArrayInputStream.readInt()
-
org.apache.avro.io.Decoder.readInt()
Reads an integer written by {@link Encoder#writeInt}.
@throws AvroTypeException If encoded value is larger than32-bits
@throws AvroTypeException If this is a stateful reader andint is not the type of the next value to be read
-
org.apache.axis2.context.externalize.SafeObjectInputStream.readInt()
-
org.apache.cassandra.io.BufferedRandomAccessFile.readInt()
-
org.apache.cassandra.io.DataInputBuffer.readInt()
-
org.apache.cassandra.io.util.BufferedRandomAccessFile.readInt()
-
org.apache.cassandra.io.util.FileDataInput.readInt()
-
org.apache.cassandra.io.util.MappedFileDataInput.readInt()
Reads a 32-bit integer from the current position in this file. Blocks until four bytes have been read, the end of the file is reached or an exception is thrown.
@return the next int value from this file.
@throws EOFException if the end of this file is detected.
@throws IOException if this file is closed or another I/O error occurs.
-
org.apache.cassandra.io.util.RandomAccessReader.readInt()
-
org.apache.cassandra.utils.vint.EncodedDataInputStream.readInt()
-
org.apache.derby.iapi.services.io.ArrayInputStream.readInt()
-
org.apache.derby.io.StorageRandomAccessFile.readInt()
-
org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView.readInt()
-
org.apache.flink.runtime.io.network.serialization.DataInputDeserializer.readInt()
-
org.apache.hadoop.fs.FSDataInputStream.readInt()
-
org.apache.hadoop.io.DataInputBuffer.readInt()
-
org.apache.hadoop.io.DataInputByteBuffer.readInt()
-
org.apache.hadoop.oncrpc.XDR.readInt()
Read an XDR signed integer and return as Java primitive integer.
-
org.apache.harmony.rmi.transport.RMIObjectInputStream.readInt()
-
org.apache.kahadb.util.DataByteArrayInputStream.readInt()
-
org.apache.lucene.store.ByteArrayDataInput.readInt()
-
org.apache.lucene.store.ChecksumIndexInput.readInt()
-
org.apache.lucene.store.DataInput.readInt()
Reads four bytes and returns an int.
@see DataOutput#writeInt(int)
-
org.apache.lucene.store.IndexInput.readInt()
Reads four bytes and returns an int.
@see IndexOutput#writeInt(int)
-
org.apache.lucene.store.InputStream.readInt()
Reads four bytes and returns an int.
@see OutputStream#writeInt(int)
-
org.apache.lucene.util.IntBlockPool.SliceReader.readInt()
-
org.apache.poi.poifs.filesystem.DocumentInputStream.readInt()
-
org.apache.poi.util.LittleEndianInput.readInt()
-
org.apache.qpid.client.message.JMSBytesMessage.readInt()
-
org.apache.qpid.client.message.JMSStreamMessage.readInt()
-
org.apache.xindice.xml.XMLCompressedInput.readInt()
-
org.codehaus.activemq.message.ActiveMQBytesMessage.readInt()
Reads a signed 32-bit integer from the bytes message stream.
@return the next four bytes from the bytes message stream, interpreted as an int
@throws JMSException if the JMS provider fails to read the message due to some internal error.
@throws MessageEOFException if unexpected end of bytes stream has been reached.
@throws MessageNotReadableException if the message is in write-only mode.
-
org.codehaus.activemq.message.ActiveMQStreamMessage.readInt()
Reads a 32-bit integer from the stream message.
@return a 32-bit integer value from the stream message, interpretedas an int
@throws JMSException if the JMS provider fails to read the messagedue to some internal error.
@throws MessageEOFException if unexpected end of message stream hasbeen reached.
@throws MessageFormatException if this type conversion is invalid.
@throws MessageNotReadableException if the message is in write-onlymode.
-
org.drools.core.common.DroolsObjectInput.readInt()
-
org.elasticsearch.common.io.stream.BytesStreamInput.readInt()
-
org.elasticsearch.common.io.stream.HandlesStreamInput.readInt()
-
org.elasticsearch.common.io.stream.InputStreamStreamInput.readInt()
-
org.elasticsearch.common.io.stream.StreamInput.readInt()
Reads four bytes and returns an int.
-
org.exist.storage.io.VariableByteArrayInput.readInt()
-
org.exist.storage.io.VariableByteInput.readInt()
Read an integer value in variable byte encoding.
@throws IOException
-
org.exoplatform.services.jcr.dataflow.serialization.ObjectReader.readInt()
Reads four input bytes and returns an
int
value. Let
a
be the first byte read,
b
be the second byte,
c
be the third byte, and
d
be the fourth byte. The value returned is:
<code> (((a & 0xff) << 24) | ((b & 0xff) << 16) | ((c & 0xff) << 8) | (d & 0xff)) </code>
This method is suitable for reading bytes written by the
writeInt
method of interface
DataOutput
.
@return the
int
value read.
@exception EOFException if this stream reaches the end before reading all the bytes.
@exception IOException if an I/O error occurs.
-
org.exoplatform.services.jcr.impl.dataflow.serialization.ObjectReaderImpl.readInt()
{@inheritDoc}
-
org.fusesource.hawtbuf.DataByteArrayInputStream.readInt()
-
org.gradle.messaging.serialize.Decoder.readInt()
Reads a signed 32 bit int value. Can read any value that was written using {@link Encoder#writeInt(int)}.
@throws EOFException when the end of the byte stream is reached before the int value can be fully read.
-
org.gradle.messaging.serialize.InputStreamBackedDecoder.readInt()
-
org.h2.store.Data.readInt()
Read an integer at the current position. The current position is incremented.
@return the value
-
org.h2.value.Transfer.readInt()
Read an int.
@return the value
-
org.hornetq.api.core.HornetQBuffer.readInt()
Gets a 32-bit integer at the current {@code readerIndex}and increases the {@code readerIndex} by {@code 4} in this buffer.
@throws IndexOutOfBoundsException if {@code this.readableBytes} is less than {@code 4}
-
org.hornetq.core.client.impl.LargeMessageBufferImpl.readInt()
-
org.hornetq.core.client.impl.LargeMessageControllerImpl.readInt()
-
org.hornetq.jms.client.HornetQStreamMessage.readInt()
-
org.iq80.leveldb.util.SliceInput.readInt()
Gets a 32-bit integer at the current {@code position}and increases the {@code position} by {@code 4} in this buffer.
@throws IndexOutOfBoundsException if {@code this.available()} is less than {@code 4}
-
org.jboss.as.protocol.ByteDataInput.readInt()
-
org.jboss.invocation.MarshalledValueInputStream.readInt()
-
org.jboss.marshalling.SimpleDataInput.readInt()
{@inheritDoc}
-
org.jboss.marshalling.Unmarshaller.readInt()
-
org.jboss.netty.buffer.BigEndianHeapChannelBuffer.readInt()
-
org.jboss.netty.buffer.ChannelBuffer.readInt()
Gets a 32-bit integer at the current {@code readerIndex}and increases the {@code readerIndex} by {@code 4} in this buffer.
@throws IndexOutOfBoundsException if {@code this.readableBytes} is less than {@code 4}
-
org.jboss.netty.buffer.ChannelBufferInputStream.readInt()
-
org.jboss.netty.buffer.DynamicChannelBuffer.readInt()
-
org.jboss.soa.esb.message.body.content.BytesBody.readInt()
-
org.jf.dexlib2.dexbacked.BaseDexBuffer.readInt()
-
org.jgroups.util.ByteArrayDataInputStream.readInt()
-
org.lealone.store.Data.readInt()
Read an integer at the current position. The current position is incremented.
@return the value
-
org.lealone.value.Transfer.readInt()
Read an int.
@return the value
-
org.lilyproject.bytes.api.DataInput.readInt()
Reads an integer from the DataInput
-
org.lilyproject.bytes.impl.DataInputImpl.readInt()
-
org.menacheri.jetclient.communication.NettyMessageBuffer.readInt()
-
org.menacheri.jetserver.communication.MessageBuffer.readInt()
Gets a 32-bit integer at the current {@code readerIndex} and increasesthe {@code readerIndex} by {@code 4} in this buffer.
@throws IndexOutOfBoundsException if {@code this.readableBytes} is less than {@code 4}
-
org.moparscape.msc.gs.connection.Packet.readInt()
Reads the next int
from the payload.
@return An int
-
org.msgpack.unpacker.BufferUnpacker.readInt()
-
org.msgpack.unpacker.Converter.readInt()
-
org.msgpack.unpacker.Unpacker.readInt()
-
org.objectweb.asm.ClassReader.readInt()
Reads a signed int value in {@link #b b}. This method is intended for {@link Attribute} sub classes, and is normally not needed by classgenerators or adapters.
@param index the start index of the value to be read in {@link #b b}.
@return the read value.
-
org.ow2.asm.ClassReader.readInt()
Reads a signed int value in {@link #b b}. This method is intended for {@link Attribute} sub classes, and is normally not needed by classgenerators or adapters.
@param index the start index of the value to be read in {@link #b b}.
@return the read value.
-
org.pdfclown.bytes.IBuffer.readInt()
-
org.voltdb.messaging.FastDeserializer.readInt()
-
research.store.StorableInput.readInt()
Reads an int from the input stream.
-
rocket.serialization.client.ObjectInputStream.readInt()
-
serp.bytecode.lowlevel.ConstantPoolTable.readInt()
Read an int value at the given offset.
-
ucar.unidata.io.RandomAccessFile.readInt()
Reads a signed 32-bit integer from this file. This method reads 4 bytes from the file. If the bytes read, in order, are
b1
,
b2
,
b3
, and
b4
, where
0 <= b1, b2, b3, b4 <= 255
, then the result is equal to:
(b1 << 24) | (b2 << 16) + (b3 << 8) + b4
This method blocks until the four bytes are read, the end of the stream is detected, or an exception is thrown.
@return the next four bytes of this file, interpreted as an
int
.
@throws EOFException if this file reaches the end before readingfour bytes.
@throws IOException if an I/O error occurs.
-
uk.ac.ucl.panda.utility.io.IndexInput.readInt()
Reads four bytes and returns an int.
@see IndexOutput#writeInt(int)
-
util.io.BufferedRandomAccessFile.readInt()