-
be.bagofwords.util.WrappedSocketConnection.writeInt()
-
bm.core.io.SerializerOutputStream.writeInt()
-
co.cask.cdap.common.io.BinaryEncoder.writeInt()
-
co.cask.cdap.common.io.Encoder.writeInt()
-
co.cask.tigon.io.BinaryEncoder.writeInt()
-
co.cask.tigon.io.Encoder.writeInt()
-
co.cask.tigon.sql.io.GDATEncoder.writeInt()
-
codechicken.lib.packet.PacketCustom.writeInt()
-
com.alibaba.dubbo.common.serialize.ObjectOutput.writeInt()
-
com.alibaba.fastjson.serializer.SerializeWriter.writeInt()
-
com.caucho.hessian.io.Hessian2Output.writeInt()
Writes an integer value to the stream. The integer will be written with the following syntax:
I b32 b24 b16 b8
@param value the integer value to write.
-
com.envoisolutions.sxc.util.XoXMLStreamWriter.writeInt()
-
com.envoisolutions.sxc.util.XoXMLStreamWriterImpl.writeInt()
-
com.esotericsoftware.kryo.io.ByteBufferOutput.writeInt()
Writes a 4 byte int.
-
com.esotericsoftware.kryo.io.Output.writeInt()
Writes a 4 byte int. Uses BIG_ENDIAN byte order.
-
com.esotericsoftware.kryo.io.OutputChunked.writeInt()
-
com.facebook.presto.jdbc.internal.netty.buffer.ChannelBuffer.writeInt()
Sets the specified 32-bit integer at the current {@code writerIndex}and increases the {@code writerIndex} by {@code 4} in this buffer.
@throws IndexOutOfBoundsException if {@code this.writableBytes} is less than {@code 4}
-
com.google.code.or.io.util.XSerializer.writeInt()
-
com.google.common.io.ByteArrayDataOutput.writeInt()
-
com.google.common.io.LittleEndianDataOutputStream.writeInt()
Writes an {@code int} as specified by{@link DataOutputStream#writeInt(int)}, except using little-endian byte order.
@throws IOException if an I/O error occurs
-
com.google.gwt.user.server.rpc.impl.ServerSerializationStreamWriter.writeInt()
-
com.hazelcast.nio.BufferObjectDataOutput.writeInt()
-
com.hazelcast.nio.ObjectDataOutput.writeInt()
-
com.hazelcast.nio.serialization.ObjectDataOutputStream.writeInt()
-
com.higherfrequencytrading.chronicle.Excerpt.writeInt()
-
com.lightcrafts.utils.file.OrderableRandomAccessFile.writeInt()
-
com.maverick.util.ByteArrayWriter.writeInt()
Write an integer to the array
@param i
@throws IOException
-
com.mobixess.jodb.core.io.IRandomAccessDataBuffer.writeInt()
-
com.orientechnologies.orient.core.storage.fs.OFile.writeInt()
-
com.orientechnologies.orient.enterprise.channel.binary.OChannelBinary.writeInt()
-
com.orientechnologies.orient.enterprise.channel.binary.OChannelBinaryAsynchClient.writeInt()
-
com.orientechnologies.orient.enterprise.channel.binary.OChannelBinaryClient.writeInt()
-
com.peterhi.obsolete.Stream.writeInt()
-
com.sshtools.j2ssh.io.ByteArrayWriter.writeInt()
@param i
@throws IOException
-
de.hpi.eworld.visualizer.simulation.traci.common.TraciOutputStream.writeInt()
-
edu.stanford.nlp.io.OutDataStreamFile.writeInt()
-
eu.stratosphere.runtime.io.serialization.DataOutputSerializer.writeInt()
-
fr.dyade.aaa.jndi2.msg.IOControl.writeInt()
-
htsjdk.tribble.util.LittleEndianOutputStream.writeInt()
-
info.ata4.io.DataOutputWriter.writeInt()
-
io.airlift.slice.DynamicSliceOutput.writeInt()
-
io.airlift.slice.SliceOutput.writeInt()
Sets the specified 32-bit integer at the current {@code writerIndex}and increases the {@code writerIndex} by {@code 4} in this buffer.
@throws IndexOutOfBoundsException if {@code this.writableBytes} is less than {@code 4}
-
io.netty.buffer.ByteBuf.writeInt()
Sets the specified 32-bit integer at the current {@code writerIndex}and increases the {@code writerIndex} by {@code 4} in this buffer.
@throws IndexOutOfBoundsException if {@code this.writableBytes} is less than {@code 4}
-
io.netty.buffer.ByteBufOutputStream.writeInt()
-
io.netty.buffer.ChannelBuffer.writeInt()
-
java.io.DataOutput.writeInt()
Writes an
int
value, which is comprised of four bytes, to the output stream. The byte values to be written, in the order shown, are:
(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 readInt
method of interface DataInput
, which will then return an int
equal to v
.
@param v the int
value to be written.
@throws IOException if an I/O error occurs.
-
java.io.DataOutputStream.writeInt()
Writes a 32-bit int to this output stream. The resulting output is the 4 bytes, highest order first, of val.
@param val the int to be written.
@throws IOException If an error occurs attempting to write to this DataOutputStream.
@see DataInput#readInt()
-
java.io.ObjectOutput.writeInt()
-
java.io.ObjectOutputStream.writeInt()
Write primitive data of type int (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.writeInt()
Writes a 32-bit int to this output stream. The resulting output is the 4 bytes, highest order first, of val.
@param val the int to be written.
@throws IOException If an error occurs attempting to write to this DataOutputStream.
@see DataInput#readInt()
-
java.nio.ByteBuffer.writeInt()
-
javax.imageio.stream.ImageOutputStream.writeInt()
Writes the 32 bits of
v
to the stream. If the stream uses network byte order, the bytes written, in order, will be:
(byte)((v >> 24) & 0xff) (byte)((v >> 16) & 0xff) (byte)((v >> 8) & 0xff) (byte)(v & 0xff)
Otheriwse, the bytes written will be:
(byte)(v & 0xff) (byte)((v >> 8) & 0xff) (byte)((v >> 16) & 0xff) (byte)((v >> 24) & 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 an int
containing the value to bewritten.
@exception IOException if an I/O error occurs.
-
javax.jms.BytesMessage.writeInt()
-
javax.jms.StreamMessage.writeInt()
-
krati.io.DataWriter.writeInt()
-
krati.io.FastDataWriter.writeInt()
@param v the int
value to be written.
@throws IOException if an I/O error occurs.
@see DataOutput#writeInt(int)
-
logisticspipes.network.LPDataOutputStream.writeInt()
-
net.timewalker.ffmq3.common.message.BytesMessageImpl.writeInt()
-
net.timewalker.ffmq3.common.message.StreamMessageImpl.writeInt()
-
net.tomp2p.storage.AlternativeCompositeByteBuf.writeInt()
-
one.nio.serial.DataStream.writeInt()
-
org.activeio.PacketData.writeInt()
-
org.activemq.message.ActiveMQBytesMessage.writeInt()
Writes an int
to the bytes message stream as four bytes, high byte first.
@param value the int
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.writeInt()
Writes an int
to the stream message.
@param value the int
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.accumulo.core.file.blockfile.ABlockWriter.writeInt()
-
org.apache.activeio.packet.PacketData.writeInt()
-
org.apache.activemq.command.ActiveMQBytesMessage.writeInt()
Writes an int
to the bytes message stream as four bytes, high byte first.
@param value the int
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.writeInt()
Writes an int
to the stream message.
@param value the int
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.writeInt()
-
org.apache.activemq.util.DataByteArrayOutputStream.writeInt()
-
org.apache.avro.io.Encoder.writeInt()
Writes a 32-bit integer.
@throws AvroTypeException If this is a stateful writer and aninteger is not expected
-
org.apache.axis2.context.externalize.SafeObjectOutputStream.writeInt()
-
org.apache.cassandra.io.DataOutputBuffer.writeInt()
-
org.apache.cassandra.io.util.DataOutputBuffer.writeInt()
-
org.apache.cassandra.io.util.DataOutputByteBuffer.writeInt()
-
org.apache.cassandra.utils.vint.EncodedDataOutputStream.writeInt()
-
org.apache.derby.iapi.services.io.FormatIdOutputStream.writeInt()
-
org.apache.derby.io.StorageRandomAccessFile.writeInt()
-
org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView.writeInt()
-
org.apache.flink.runtime.io.network.serialization.DataOutputSerializer.writeInt()
-
org.apache.hadoop.fs.FSDataOutputStream.writeInt()
-
org.apache.hadoop.io.DataOutputBuffer.writeInt()
Overwrite an integer into the internal buffer. Note that this call can only be used to overwrite existing data in the buffer, i.e., buffer#count cannot be increased, and DataOutputStream#written cannot be increased.
-
org.apache.hadoop.oncrpc.XDR.writeInt()
Write Java primitive integer as XDR signed integer. Definition of XDR signed integer from RFC 4506:
An XDR signed integer is a 32-bit datum that encodes an integer in the range [-2147483648,2147483647]. The integer is represented in two's complement notation. The most and least significant bytes are 0 and 3, respectively. Integers are declared as follows: int identifier; (MSB) (LSB) +-------+-------+-------+-------+ |byte 0 |byte 1 |byte 2 |byte 3 | INTEGER +-------+-------+-------+-------+ <------------32 bits------------>
-
org.apache.hadoop.typedbytes.TypedBytesOutput.writeInt()
Writes an integer as a typed bytes sequence.
@param i the integer to be written
@throws IOException
-
org.apache.jute.BinaryOutputArchive.writeInt()
-
org.apache.jute_voltpatches.BinaryOutputArchive.writeInt()
-
org.apache.kahadb.util.DataByteArrayOutputStream.writeInt()
-
org.apache.lucene.store.ByteArrayDataOutput.writeInt()
-
org.apache.lucene.store.ChecksumIndexOutput.writeInt()
-
org.apache.lucene.store.IndexOutput.writeInt()
Writes an int as four bytes.
@see IndexInput#readInt()
-
org.apache.lucene.store.OutputStream.writeInt()
Writes an int as four bytes.
@see InputStream#readInt()
-
org.apache.poi.util.LittleEndianByteArrayOutputStream.writeInt()
-
org.apache.poi.util.LittleEndianOutput.writeInt()
-
org.apache.poi.util.LittleEndianOutputStream.writeInt()
-
org.apache.qpid.client.message.JMSBytesMessage.writeInt()
-
org.apache.qpid.client.message.JMSStreamMessage.writeInt()
-
org.apache.tapestry.internal.util.Base64ObjectOutputStream.writeInt()
-
org.apache.tapestry5.internal.util.Base64ObjectOutputStream.writeInt()
-
org.codehaus.activemq.message.ActiveMQBytesMessage.writeInt()
Writes an int
to the bytes message stream as four bytes, high byte first.
@param value the int
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.writeInt()
Writes an int
to the stream message.
@param value the int
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.codehaus.stax2.typed.TypedXMLStreamWriter.writeInt()
3.org/TR/xmlschema-2/#integer">XML Schema integer data type.
-
org.elasticsearch.common.io.stream.BytesStreamOutput.writeInt()
-
org.elasticsearch.common.io.stream.HandlesStreamOutput.writeInt()
-
org.elasticsearch.common.netty.buffer.ChannelBuffer.writeInt()
-
org.exist.storage.io.VariableByteOutputStream.writeInt()
-
org.exoplatform.services.jcr.dataflow.serialization.ObjectWriter.writeInt()
Writes an
int
value, which is comprised of four bytes, to the output stream. The byte values to be written, in the order shown, are:
<code> (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 readInt
method of interface DataInput
, which will then return an int
equal to v
.
@param v the int
value to be written.
@exception IOException if an I/O error occurs.
-
org.exoplatform.services.jcr.impl.dataflow.serialization.ObjectWriterImpl.writeInt()
{@inheritDoc}
-
org.fusesource.hawtbuf.BufferEditor.writeInt()
-
org.fusesource.hawtbuf.DataByteArrayOutputStream.writeInt()
-
org.gradle.messaging.serialize.FlushableEncoder.writeInt()
-
org.gradle.messaging.serialize.OutputStreamBackedEncoder.writeInt()
-
org.h2.store.Data.writeInt()
Write an integer at the current position. The current position is incremented.
@param x the value
-
org.h2.value.Transfer.writeInt()
Write an int.
@param x the value
@return itself
-
org.hornetq.api.core.HornetQBuffer.writeInt()
Sets the specified 32-bit integer at the current {@code writerIndex}and increases the {@code writerIndex} by {@code 4} in this buffer.
@throws IndexOutOfBoundsException if {@code this.writableBytes} is less than {@code 4}
-
org.hornetq.jms.client.HornetQStreamMessage.writeInt()
-
org.hornetq.jms.tests.message.SimpleJMSStreamMessage.writeInt()
-
org.hsqldb.lib.DataOutputStream.writeInt()
-
org.hsqldb.lib.Storage.writeInt()
-
org.iq80.leveldb.util.SliceOutput.writeInt()
Sets the specified 32-bit integer at the current {@code writerIndex}and increases the {@code writerIndex} by {@code 4} in this buffer.
@throws IndexOutOfBoundsException if {@code this.writableBytes} is less than {@code 4}
-
org.jboss.as.protocol.ByteDataOutput.writeInt()
-
org.jboss.as.protocol.mgmt.FlushableDataOutput.writeInt()
-
org.jboss.invocation.MarshalledValueOutputStream.writeInt()
-
org.jboss.jms.message.JBossBytesMessage.writeInt()
-
org.jboss.jms.message.JBossStreamMessage.writeInt()
-
org.jboss.marshalling.Marshaller.writeInt()
-
org.jboss.marshalling.SimpleDataOutput.writeInt()
{@inheritDoc}
-
org.jboss.netty.buffer.BigEndianHeapChannelBuffer.writeInt()
-
org.jboss.netty.buffer.ChannelBuffer.writeInt()
Sets the specified 32-bit integer at the current {@code writerIndex}and increases the {@code writerIndex} by {@code 4} in this buffer.
@throws IndexOutOfBoundsException if {@code this.writableBytes} is less than {@code 4}
-
org.jboss.remoting3.jmx.protocol.CancellableDataOutputStream.writeInt()
-
org.jboss.remotingjmx.protocol.CancellableDataOutputStream.writeInt()
-
org.jboss.soa.esb.message.body.content.BytesBody.writeInt()
-
org.jboss.test.messaging.jms.message.SimpleJMSStreamMessage.writeInt()
-
org.jgroups.util.ByteArrayDataOutputStream.writeInt()
-
org.jnode.assembler.x86.X86Assembler.writeINT()
Create a int vector
@param vector
-
org.lealone.store.Data.writeInt()
Write an integer at the current position. The current position is incremented.
@param x the value
-
org.lealone.value.Transfer.writeInt()
Write an int.
@param x the value
@return itself
-
org.lilyproject.bytes.api.DataOutput.writeInt()
Writes an integer to the DataOutput
-
org.lilyproject.bytes.impl.DataOutputImpl.writeInt()
-
org.menacheri.jetclient.communication.NettyMessageBuffer.writeInt()
-
org.menacheri.jetserver.communication.NettyMessageBuffer.writeInt()
-
org.msgpack.packer.BufferPacker.writeInt()
-
org.msgpack.packer.Packer.writeInt()
-
org.msgpack.packer.Unconverter.writeInt()
-
org.tmatesoft.hg.internal.DataSerializer.OutputStreamSerializer.writeInt()
-
org.voltdb.messaging.FastSerializer.writeInt()
-
parquet.column.values.rle.RunLengthBitPackingHybridEncoder.writeInt()
-
research.store.StorableOutput.writeInt()
Writes an int to the output stream.
-
rocket.serialization.client.ObjectOutputStream.writeInt()
-
streamer.ByteBuffer.writeInt()
Write int in network order. Cursor is advanced by 4.
-
tahrir.tools.ByteArraySegment.ByteArraySegmentBuilder.writeInt()
-
ucar.unidata.io.RandomAccessFile.writeInt()
Writes an int
to the file as four bytes, high byte first.
@param v an int
to be written.
@throws IOException if an I/O error occurs.
-
uk.ac.ucl.panda.utility.io.IndexOutput.writeInt()
Writes an int as four bytes.
@see IndexInput#readInt()