-
be.bagofwords.util.WrappedSocketConnection.readLong()
-
ch.ethz.inf.vs.scandium.util.DatagramReader.readLong()
Reads a sequence of bits from the stream
@param numBits The number of bits to read
@return A Long containing the bits read
-
co.cask.cdap.common.io.BinaryDecoder.readLong()
-
co.cask.cdap.common.io.Decoder.readLong()
-
co.cask.tephra.snapshot.BinaryDecoder.readLong()
Read one long int from the input.
@return the read number
@throws java.io.IOException If there is IO error.
@throws java.io.EOFException If end of file reached.
-
com.alibaba.dubbo.common.serialize.ObjectInput.readLong()
-
com.alibaba.fastjson.JSONReader.readLong()
-
com.caucho.hessian.io.Hessian2Input.readLong()
Reads a long
L b64 b56 b48 b40 b32 b24 b16 b8
-
com.caucho.json.JsonInput.readLong()
-
com.esotericsoftware.kryo.io.Input.readLong()
Reads an 8 byte long.
-
com.esotericsoftware.kryo.io.UnsafeInput.readLong()
Reads an 8 byte long.
-
com.esotericsoftware.kryo.io.UnsafeMemoryInput.readLong()
Reads an 8 byte long.
-
com.eviware.soapui.support.xml.XmlObjectConfigurationReader.readLong()
-
com.firefly.utils.json.JsonReader.readLong()
-
com.firefly.utils.json.io.JsonStringReader.readLong()
-
com.google.code.or.io.XInputStream.readLong()
-
com.google.code.or.io.util.XDeserializer.readLong()
-
com.google.common.io.ByteArrayDataInput.readLong()
-
com.hazelcast.nio.ObjectDataInput.readLong()
-
com.higherfrequencytrading.chronicle.Excerpt.readLong()
-
com.mobixess.jodb.core.io.IRandomAccessDataBuffer.readLong()
-
com.orientechnologies.orient.core.storage.fs.OFile.readLong()
-
com.orientechnologies.orient.enterprise.channel.binary.OChannelBinaryAsynchClient.readLong()
-
com.orientechnologies.orient.enterprise.channel.binary.OChannelBinaryClient.readLong()
-
com.peterhi.obsolete.Stream.readLong()
-
com.sun.enterprise.naming.util.ObjectInputStreamWithLoader.readLong()
-
fiftyone.mobile.detection.readers.TrieReader.readLong()
Read an signed long from the file at the current location.
@return The Value read.
@throws IOException
-
htsjdk.tribble.util.LittleEndianInputStream.readLong()
-
hudson.remoting.ObjectInputStreamEx.readLong()
-
io.netty.buffer.ByteBuf.readLong()
Gets a 64-bit integer at the current {@code readerIndex}and increases the {@code readerIndex} by {@code 8} in this buffer.
@throws IndexOutOfBoundsException if {@code this.readableBytes} is less than {@code 8}
-
java.io.DataInput.readLong()
Reads a 64-bit long
value from this stream.
@return the next long
value from the source stream.
@throws IOException If a problem occurs reading from this stream.
@see DataOutput#writeLong(long)
-
java.io.DataInputStream.readLong()
See the general contract of the
readLong
method of
DataInput
.
Bytes for this operation are read from the contained input stream.
@return the next eight bytes of this input stream, interpreted as along
.
@exception EOFException if this input stream reaches the end beforereading eight 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.readLong()
-
java.io.ObjectInputStream.readLong()
Reads and returns primitive data of type long read from the receiver
@return a long saved as primitive data usingObjectOutputStream.writeLong()
@throws IOException If an IO exception happened when reading the primitive data.
-
java.io.RandomAccessFile.readLong()
Reads a 64-bit long
value from this stream.
@return long the next long
value from the source stream.
@throws IOException If a problem occurs reading from this DataInputStream.
@see DataOutput#writeLong(long)
-
javax.imageio.stream.ImageInputStream.readLong()
Reads 8 bytes from the stream, and (conceptually) concatenates them according to the current byte order and returns the result as a
long
.
The bit offset within the stream is reset to zero before the read occurs.
@return a signed long 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.readLong()
-
javax.imageio.stream.MemoryCacheImageInputStream.readLong()
-
javax.jms.BytesMessage.readLong()
-
javax.jms.StreamMessage.readLong()
-
javax.sql.rowset.serial.SQLInputImpl.readLong()
Retrieves the next attribute in this
SQLInputImpl
object as a
long
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.io.ChannelReader.readLong()
-
krati.io.DataReader.readLong()
-
net.jini.io.MarshalInputStream.readLong()
-
net.timewalker.ffmq3.common.message.BytesMessageImpl.readLong()
-
net.timewalker.ffmq3.common.message.StreamMessageImpl.readLong()
-
nom.tam.util.BufferedDataInputStream.readLong()
-
org.activemq.message.ActiveMQBytesMessage.readLong()
Reads a signed 64-bit integer from the bytes message stream.
@return the next eight bytes from the bytes message stream, interpreted as a long
@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.readLong()
Reads a 64-bit integer from the stream message.
@return a 64-bit integer value from the stream message, interpreted asa long
@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.readLong()
Read a long.
@return The long that was read.
-
org.apache.activemq.command.ActiveMQBytesMessage.readLong()
Reads a signed 64-bit integer from the bytes message stream.
@return the next eight bytes from the bytes message stream, interpretedas a long
@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.readLong()
Reads a 64-bit integer from the stream message.
@return a 64-bit integer value from the stream message, interpreted as along
@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.readLong()
-
org.apache.avro.io.Decoder.readLong()
Reads a long written by {@link Encoder#writeLong}.
@throws AvroTypeException If this is a stateful reader andlong is not the type of the next value to be read
-
org.apache.axis2.context.externalize.SafeObjectInputStream.readLong()
-
org.apache.cassandra.io.BufferedRandomAccessFile.readLong()
-
org.apache.cassandra.io.DataInputBuffer.readLong()
-
org.apache.cassandra.io.util.BufferedRandomAccessFile.readLong()
-
org.apache.cassandra.io.util.FileDataInput.readLong()
-
org.apache.cassandra.io.util.RandomAccessReader.readLong()
-
org.apache.cassandra.utils.vint.EncodedDataInputStream.readLong()
-
org.apache.catalina.util.CustomObjectInputStream.readLong()
-
org.apache.derby.iapi.services.io.ArrayInputStream.readLong()
-
org.apache.derby.io.StorageRandomAccessFile.readLong()
-
org.apache.hadoop.fs.FSDataInputStream.readLong()
-
org.apache.hadoop.io.DataInputBuffer.readLong()
-
org.apache.harmony.rmi.transport.RMIObjectInputStream.readLong()
-
org.apache.jute.BinaryInputArchive.readLong()
-
org.apache.jute.InputArchive.readLong()
-
org.apache.jute_voltpatches.BinaryInputArchive.readLong()
-
org.apache.jute_voltpatches.InputArchive.readLong()
-
org.apache.kahadb.util.DataByteArrayInputStream.readLong()
-
org.apache.lucene.store.ChecksumIndexInput.readLong()
-
org.apache.lucene.store.IndexInput.readLong()
Reads eight bytes and returns a long.
@see IndexOutput#writeLong(long)
-
org.apache.lucene.store.InputStream.readLong()
Reads eight bytes and returns a long.
@see OutputStream#writeLong(long)
-
org.apache.poi.poifs.filesystem.DocumentInputStream.readLong()
-
org.apache.poi.util.LittleEndianInput.readLong()
-
org.apache.qpid.client.message.JMSBytesMessage.readLong()
-
org.apache.qpid.client.message.JMSStreamMessage.readLong()
-
org.apache.qpid.proton.TestDecoder.readLong()
-
org.codehaus.activemq.message.ActiveMQBytesMessage.readLong()
Reads a signed 64-bit integer from the bytes message stream.
@return the next eight bytes from the bytes message stream, interpreted as a long
@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.readLong()
Reads a 64-bit integer from the stream message.
@return a 64-bit integer value from the stream message, interpreted asa long
@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.elasticsearch.common.io.stream.BytesStreamInput.readLong()
-
org.elasticsearch.common.io.stream.StreamInput.readLong()
Reads eight bytes and returns a long.
-
org.elasticsearch.common.netty.buffer.ChannelBuffer.readLong()
-
org.exist.storage.io.VariableByteInput.readLong()
Read a long value in variable byte encoding.
@throws IOException
-
org.exoplatform.services.jcr.dataflow.serialization.ObjectReader.readLong()
Reads eight input bytes and returns a
long
value. Let
a
be the first byte read,
b
be the second byte,
c
be the third byte,
d
be the fourth byte,
e
be the fifth byte,
f
be the sixth byte,
g
be the seventh byte, and
h
be the eighth byte. The value returned is:
<code> (((long)(a & 0xff) << 56) | ((long)(b & 0xff) << 48) | ((long)(c & 0xff) << 40) | ((long)(d & 0xff) << 32) | ((long)(e & 0xff) << 24) | ((long)(f & 0xff) << 16) | ((long)(g & 0xff) << 8) | ((long)(h & 0xff))) </code>
This method is suitable for reading bytes written by the writeLong
method of interface DataOutput
.
@return the long
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.readLong()
{@inheritDoc}
-
org.exoplatform.services.jcr.impl.dataflow.serialization.ObjectZipReaderImpl.readLong()
-
org.exoplatform.services.jcr.impl.dataflow.serialization.ZipObjectReader.readLong()
-
org.fusesource.hawtbuf.DataByteArrayInputStream.readLong()
-
org.gradle.messaging.serialize.Decoder.readLong()
Reads a signed 64 bit long value. Can read any value that was written using {@link Encoder#writeLong(long)}.
@throws EOFException when the end of the byte stream is reached before the long value can be fully read.
-
org.gradle.messaging.serialize.InputStreamBackedDecoder.readLong()
-
org.h2.store.Data.readLong()
Read a long value. This method reads two int values and combines them.
@return the long value
-
org.hornetq.api.core.HornetQBuffer.readLong()
Gets a 64-bit integer at the current {@code readerIndex}and increases the {@code readerIndex} by {@code 8} in this buffer.
@throws IndexOutOfBoundsException if {@code this.readableBytes} is less than {@code 8}
-
org.hornetq.core.client.impl.LargeMessageBufferImpl.readLong()
-
org.hornetq.core.client.impl.LargeMessageControllerImpl.readLong()
-
org.hornetq.jms.client.HornetQStreamMessage.readLong()
-
org.infinispan.client.hotrod.impl.transport.Transport.readLong()
-
org.iq80.leveldb.util.SliceInput.readLong()
Gets a 64-bit integer at the current {@code position}and increases the {@code position} by {@code 8} in this buffer.
@throws IndexOutOfBoundsException if {@code this.available()} is less than {@code 8}
-
org.jboss.as.protocol.ByteDataInput.readLong()
-
org.jboss.marshalling.Unmarshaller.readLong()
-
org.jboss.netty.buffer.ChannelBuffer.readLong()
Gets a 64-bit integer at the current {@code readerIndex}and increases the {@code readerIndex} by {@code 8} in this buffer.
@throws IndexOutOfBoundsException if {@code this.readableBytes} is less than {@code 8}
-
org.jboss.netty.buffer.ChannelBufferInputStream.readLong()
-
org.jgroups.util.ByteArrayDataInputStream.readLong()
-
org.lilyproject.bytes.api.DataInput.readLong()
Reads a long from the DataInput
-
org.lilyproject.bytes.impl.DataInputImpl.readLong()
-
org.msgpack.unpacker.BufferUnpacker.readLong()
-
org.msgpack.unpacker.Converter.readLong()
-
org.msgpack.unpacker.Unpacker.readLong()
-
org.openquark.cal.internal.serialization.RecordInputStream.readLong()
See the general contract of the
readLong
method of
DataInput
.
Bytes for this operation are read from the contained input stream.
@return the next eight bytes of this input stream, interpreted as along
.
@exception EOFException if this input stream reaches the end before reading eight bytes.
@exception IOException if an I/O error occurs.
@see RecordInputStream#in
-
org.openrdf.http.client.connections.HTTPRequest.readLong()
-
org.persvr.util.BufferedDataInput.readLong()
-
org.springframework.batch.item.file.transform.FieldSet.readLong()
Read the 'long
' value at index 'index
'.
@param index the field index.
@throws IndexOutOfBoundsException if the index is out of bounds.
-
org.voltdb.messaging.FastDeserializer.readLong()
-
parquet.column.values.plain.PlainValuesReader.LongPlainValuesReader.readLong()
-
uk.ac.ucl.panda.utility.io.IndexInput.readLong()
Reads eight bytes and returns a long.
@see IndexOutput#writeLong(long)