-
be.bagofwords.util.WrappedSocketConnection.writeLong()
-
bm.core.io.SerializerOutputStream.writeLong()
-
ch.ethz.inf.vs.scandium.util.DatagramWriter.writeLong()
Writes a sequence of bits to the stream
@param data A Long containing the bits to write
@param numBits The number of bits to write
-
co.cask.cdap.common.io.BinaryEncoder.writeLong()
-
co.cask.cdap.common.io.Encoder.writeLong()
-
co.cask.tephra.snapshot.BinaryEncoder.writeLong()
write a single long int value.
@throws java.io.IOException If there is IO error.
-
co.cask.tigon.sql.io.GDATEncoder.writeLong()
-
com.alibaba.dubbo.common.serialize.ObjectOutput.writeLong()
-
com.alibaba.fastjson.serializer.SerializeWriter.writeLong()
-
com.caucho.hessian.io.Hessian2Output.writeLong()
Writes a long value to the stream. The long will be written with the following syntax:
L b64 b56 b48 b40 b32 b24 b16 b8
@param value the long value to write.
-
com.envoisolutions.sxc.util.XoXMLStreamWriter.writeLong()
-
com.envoisolutions.sxc.util.XoXMLStreamWriterImpl.writeLong()
-
com.esotericsoftware.kryo.io.Output.writeLong()
Writes an 8 byte long. Uses BIG_ENDIAN byte order.
-
com.facebook.presto.jdbc.internal.netty.buffer.ChannelBuffer.writeLong()
Sets the specified 64-bit long integer at the current {@code writerIndex} and increases the {@code writerIndex} by {@code 8}in this buffer.
@throws IndexOutOfBoundsException if {@code this.writableBytes} is less than {@code 8}
-
com.facebook.presto.jdbc.internal.type.type.Type.writeLong()
Writes the long value into the {@code BlockBuilder}.
-
com.facebook.presto.spi.type.Type.writeLong()
Writes the long value into the {@code BlockBuilder}.
-
com.google.code.or.io.util.XSerializer.writeLong()
-
com.google.common.io.ByteArrayDataOutput.writeLong()
-
com.hazelcast.nio.ObjectDataOutput.writeLong()
-
com.higherfrequencytrading.chronicle.Excerpt.writeLong()
-
com.mobixess.jodb.core.io.IRandomAccessDataBuffer.writeLong()
-
com.orientechnologies.orient.core.storage.fs.OFile.writeLong()
-
com.peterhi.obsolete.Stream.writeLong()
-
com.sleepycat.bind.tuple.TupleOutput.writeLong()
Writes an signed long (eight byte) value to the buffer. Writes values that can be read using {@link TupleInput#readLong}.
@param val is the value to write to the buffer.
@return this tuple output object.
@see
Integer Formats
-
htsjdk.tribble.util.LittleEndianOutputStream.writeLong()
-
io.netty.buffer.ByteBuf.writeLong()
Sets the specified 64-bit long integer at the current {@code writerIndex} and increases the {@code writerIndex} by {@code 8}in this buffer.
@throws IndexOutOfBoundsException if {@code this.writableBytes} is less than {@code 8}
-
io.netty.buffer.ByteBufOutputStream.writeLong()
-
io.netty.buffer.ChannelBuffer.writeLong()
-
java.io.DataOutput.writeLong()
Writes a
long
value, which is comprised of eight bytes, to the output stream. The byte values to be written, in the order shown, are:
(byte)(0xff & (v >> 56)) (byte)(0xff & (v >> 48)) (byte)(0xff & (v >> 40)) (byte)(0xff & (v >> 32)) (byte)(0xff & (v >> 24)) (byte)(0xff & (v >> 16)) (byte)(0xff & (v >> 8)) (byte)(0xff & v)
The bytes written by this method may be read by the readLong
method of interface DataInput
, which will then return a long
equal to v
.
@param v the long
value to be written.
@throws IOException if an I/O error occurs.
-
java.io.DataOutputStream.writeLong()
Writes a 64-bit long to this output stream. The resulting output is the 8 bytes, highest order first, of val.
@param val the long to be written.
@throws IOException If an error occurs attempting to write to this DataOutputStream.
@see DataInput#readLong()
-
java.io.ObjectOutput.writeLong()
-
java.io.ObjectOutputStream.writeLong()
Write primitive data of type long (value
)into the receiver's underlying stream.
@param value The primitive data to write
@throws IOException If an IO exception happened when writing the primitive data.
-
java.io.RandomAccessFile.writeLong()
Writes a 64-bit long to this output stream. The resulting output is the 8 bytes, highest order first, of val.
@param val the long to be written.
@throws IOException If an error occurs attempting to write to this DataOutputStream.
@see DataInput#readLong()
-
javax.imageio.stream.ImageOutputStream.writeLong()
Writes the 64 bits of
v
to the stream. If the stream uses network byte order, the bytes written, in order, will be:
(byte)((v >> 56) & 0xff) (byte)((v >> 48) & 0xff) (byte)((v >> 40) & 0xff) (byte)((v >> 32) & 0xff) (byte)((v >> 24) & 0xff) (byte)((v >> 16) & 0xff) (byte)((v >> 8) & 0xff) (byte)(v & 0xff)
Otherwise, the bytes written will be:
(byte)(v & 0xff) (byte)((v >> 8) & 0xff) (byte)((v >> 16) & 0xff) (byte)((v >> 24) & 0xff) (byte)((v >> 32) & 0xff) (byte)((v >> 40) & 0xff) (byte)((v >> 48) & 0xff) (byte)((v >> 56) & 0xff)
If the bit offset within the stream is non-zero, the remainder of the current byte is padded with 0s and written out first. The bit offset will be 0 after the write.
@param v a long
containing the value to bewritten.
@exception IOException if an I/O error occurs.
-
javax.jms.BytesMessage.writeLong()
-
javax.jms.StreamMessage.writeLong()
-
krati.io.DataWriter.writeLong()
-
krati.io.FastDataWriter.writeLong()
@param v the long
value to be written.
@throws IOException if an I/O error occurs.
@see DataOutput#writeLong(long)
-
net.jini.io.MarshalOutputStream.writeLong()
-
net.timewalker.ffmq3.common.message.BytesMessageImpl.writeLong()
-
net.timewalker.ffmq3.common.message.StreamMessageImpl.writeLong()
-
org.activemq.message.ActiveMQBytesMessage.writeLong()
Writes a long
to the bytes message stream as eight bytes, high byte first.
@param value the long
to be written
@throws JMSException if the JMS provider fails to write the message due to some internal error.
@throws MessageNotWriteableException if the message is in read-only mode.
-
org.activemq.message.ActiveMQStreamMessage.writeLong()
Writes a long
to the stream message.
@param value the long
value to be written
@throws JMSException if the JMS provider fails to write the messagedue to some internal error.
@throws MessageNotWriteableException if the message is in read-onlymode.
-
org.apache.activemq.command.ActiveMQBytesMessage.writeLong()
Writes a long
to the bytes message stream as eight bytes, high byte first.
@param value the long
to be written
@throws JMSException if the JMS provider fails to write the message dueto some internal error.
@throws MessageNotWriteableException if the message is in read-only mode.
-
org.apache.activemq.command.ActiveMQStreamMessage.writeLong()
Writes a long
to the stream message.
@param value the long
value to be written
@throws JMSException if the JMS provider fails to write the message dueto some internal error.
@throws MessageNotWriteableException if the message is in read-only mode.
-
org.apache.activemq.store.kahadb.disk.util.DataByteArrayOutputStream.writeLong()
-
org.apache.activemq.util.DataByteArrayOutputStream.writeLong()
-
org.apache.avro.io.BinaryEncoder.writeLong()
-
org.apache.avro.io.Encoder.writeLong()
Write a 64-bit integer.
@throws AvroTypeException If this is a stateful writer and along is not expected
-
org.apache.axis2.context.externalize.SafeObjectOutputStream.writeLong()
-
org.apache.cassandra.io.DataOutputBuffer.writeLong()
-
org.apache.cassandra.io.util.DataOutputBuffer.writeLong()
-
org.apache.cassandra.utils.vint.EncodedDataOutputStream.writeLong()
-
org.apache.derby.iapi.services.io.FormatIdOutputStream.writeLong()
-
org.apache.hadoop.fs.FSDataOutputStream.writeLong()
-
org.apache.hadoop.io.DataOutputBuffer.writeLong()
-
org.apache.harmony.rmi.transport.RMIObjectOutputStream.writeLong()
-
org.apache.jute.OutputArchive.writeLong()
-
org.apache.jute_voltpatches.OutputArchive.writeLong()
-
org.apache.kahadb.util.DataByteArrayOutputStream.writeLong()
-
org.apache.lucene.store.ByteArrayDataOutput.writeLong()
-
org.apache.lucene.store.ChecksumIndexOutput.writeLong()
-
org.apache.lucene.store.IndexOutput.writeLong()
Writes a long as eight bytes.
@see IndexInput#readLong()
-
org.apache.lucene.store.OutputStream.writeLong()
Writes a long as eight bytes.
@see InputStream#readLong()
-
org.apache.poi.util.LittleEndianOutputStream.writeLong()
-
org.apache.qpid.client.message.JMSBytesMessage.writeLong()
-
org.apache.qpid.client.message.JMSStreamMessage.writeLong()
-
org.codehaus.activemq.message.ActiveMQBytesMessage.writeLong()
Writes a long
to the bytes message stream as eight bytes, high byte first.
@param value the long
to be written
@throws JMSException if the JMS provider fails to write the message due to some internal error.
@throws MessageNotWriteableException if the message is in read-only mode.
-
org.codehaus.activemq.message.ActiveMQStreamMessage.writeLong()
Writes a long
to the stream message.
@param value the long
value to be written
@throws JMSException if the JMS provider fails to write the messagedue to some internal error.
@throws MessageNotWriteableException if the message is in read-onlymode.
-
org.elasticsearch.common.io.stream.BytesStreamOutput.writeLong()
-
org.elasticsearch.common.io.stream.HandlesStreamOutput.writeLong()
-
org.elasticsearch.common.io.stream.StreamOutput.writeLong()
Writes a long as eight bytes.
-
org.elasticsearch.common.netty.buffer.ChannelBuffer.writeLong()
-
org.exist.storage.io.VariableByteOutputStream.writeLong()
-
org.exoplatform.services.jcr.dataflow.serialization.ObjectWriter.writeLong()
Writes a
long
value, which is comprised of eight bytes, to the output stream. The byte values to be written, in the order shown, are:
<code> (byte)(0xff & (v >> 56)) (byte)(0xff & (v >> 48)) (byte)(0xff & (v >> 40)) (byte)(0xff & (v >> 32)) (byte)(0xff & (v >> 24)) (byte)(0xff & (v >> 16)) (byte)(0xff & (v >> 8)) (byte)(0xff & v) </code>
The bytes written by this method may be read by the readLong
method of interface DataInput
, which will then return a long
equal to v
.
@param v the long
value to be written.
@exception IOException if an I/O error occurs.
-
org.exoplatform.services.jcr.impl.dataflow.serialization.ObjectWriterImpl.writeLong()
{@inheritDoc}
-
org.exoplatform.services.jcr.impl.dataflow.serialization.ObjectZipWriterImpl.writeLong()
-
org.fusesource.hawtbuf.DataByteArrayOutputStream.writeLong()
-
org.gradle.messaging.serialize.FlushableEncoder.writeLong()
-
org.gradle.messaging.serialize.OutputStreamBackedEncoder.writeLong()
-
org.h2.value.Transfer.writeLong()
Write a long.
@param x the value
@return itself
-
org.hornetq.api.core.HornetQBuffer.writeLong()
Sets the specified 64-bit long integer at the current {@code writerIndex} and increases the {@code writerIndex} by {@code 8}in this buffer.
@throws IndexOutOfBoundsException if {@code this.writableBytes} is less than {@code 8}
-
org.hornetq.jms.client.HornetQStreamMessage.writeLong()
-
org.hornetq.jms.tests.message.SimpleJMSStreamMessage.writeLong()
-
org.hsqldb.lib.Storage.writeLong()
-
org.hsqldb_voltpatches.lib.Storage.writeLong()
-
org.infinispan.client.hotrod.impl.transport.Transport.writeLong()
-
org.iq80.leveldb.util.SliceOutput.writeLong()
Sets the specified 64-bit long integer at the current {@code writerIndex} and increases the {@code writerIndex} by {@code 8}in this buffer.
@throws IndexOutOfBoundsException if {@code this.writableBytes} is less than {@code 8}
-
org.jboss.jms.message.JBossBytesMessage.writeLong()
-
org.jboss.jms.message.JBossStreamMessage.writeLong()
-
org.jboss.marshalling.Marshaller.writeLong()
-
org.jboss.netty.buffer.ChannelBuffer.writeLong()
Sets the specified 64-bit long integer at the current {@code writerIndex} and increases the {@code writerIndex} by {@code 8}in this buffer.
@throws IndexOutOfBoundsException if {@code this.writableBytes} is less than {@code 8}
-
org.jboss.test.messaging.jms.message.SimpleJMSStreamMessage.writeLong()
-
org.jgroups.util.ByteArrayDataOutputStream.writeLong()
-
org.lealone.value.Transfer.writeLong()
Write a long.
@param x the value
@return itself
-
org.lilyproject.bytes.api.DataOutput.writeLong()
Writes a long to the DataOutput
-
org.lilyproject.bytes.impl.DataOutputImpl.writeLong()
-
org.msgpack.packer.BufferPacker.writeLong()
-
org.msgpack.packer.Packer.writeLong()
-
org.msgpack.packer.Unconverter.writeLong()
-
org.voltdb.messaging.FastSerializer.writeLong()
-
parquet.column.values.plain.PlainValuesWriter.writeLong()
-
uk.ac.ucl.panda.utility.io.IndexOutput.writeLong()
Writes a long as eight bytes.
@see IndexInput#readLong()