-
br.org.scadabr.dnp34j.master.common.utils.Buffer.writeBytes()
Push 2 bytes on current window.
@param anInt value added to current window as 2 LSB bytes
-
ch.ethz.inf.vs.scandium.util.DatagramWriter.writeBytes()
Writes a sequence of bytes to the stream
@param bytes The sequence of bytes to write
-
ch.ethz.ssh2.packets.TypesWriter.writeBytes()
-
com.alibaba.dubbo.common.serialize.ObjectOutput.writeBytes()
-
com.alibaba.dubbo.remoting.buffer.ChannelBuffer.writeBytes()
Transfers the specified source array's data to this buffer starting at the current {@code writerIndex} and increases the {@code writerIndex} bythe number of the transferred bytes (= {@code src.length}).
@throws IndexOutOfBoundsException if {@code src.length} is greater than{@code this.writableBytes}
-
com.couchbase.client.deps.io.netty.buffer.ByteBuf.writeBytes()
-
com.esotericsoftware.kryo.io.Output.writeBytes()
Writes the bytes. Note the byte[] length is not written.
-
com.esotericsoftware.kryo.io.UnsafeMemoryOutput.writeBytes()
Output count bytes from a memory region starting at the given #{offset} inside the in-memory representation of obj object.
@param obj
@param offset
@param count
-
com.esotericsoftware.kryo.io.UnsafeOutput.writeBytes()
Output count bytes from a memory region starting at the given #{offset} inside the in-memory representation of obj object.
@param obj
@param offset
@param count
-
com.facebook.presto.jdbc.internal.netty.buffer.ChannelBuffer.writeBytes()
Transfers the specified source buffer's data to this buffer starting at the current {@code writerIndex} until the source buffer becomesunreadable, and increases the {@code writerIndex} by the number ofthe transferred bytes. This method is basically same with {@link #writeBytes(ChannelBuffer,int,int)}, except that this method increases the {@code readerIndex} of the source buffer by the number ofthe transferred bytes while {@link #writeBytes(ChannelBuffer,int,int)}does not.
@throws IndexOutOfBoundsException if {@code src.readableBytes} is greater than{@code this.writableBytes}
-
com.facebook.presto.spi.block.BlockBuilder.writeBytes()
Write a byte sequences to the current entry;
-
com.facebook.presto.spi.block.FixedWidthBlockBuilder.writeBytes()
-
com.facebook.presto.spi.block.VariableWidthBlockBuilder.writeBytes()
-
com.fasterxml.storemate.shared.ByteContainer.writeBytes()
-
com.google.code.or.io.util.XSerializer.writeBytes()
-
com.google.opengse.iobuffer.IOBuffer.writeBytes()
Writes the supplied byte array to the i/o buffer. This method should not be mixed with calls to any of the IOBuffer character write
methods. If using separate read/write threads, call by writer.
@param buf is the source byte array
@exception IOException
-
com.google.protobuf.CodedOutputStream.writeBytes()
Write a {@code bytes} field, including tag, to the stream.
-
com.higherfrequencytrading.chronicle.Excerpt.writeBytes()
-
com.orientechnologies.orient.enterprise.channel.binary.OChannelBinary.writeBytes()
Send byte arrays split in chunks of maxChunkSize bytes
-
com.orientechnologies.orient.enterprise.channel.binary.OChannelBinaryAsynchClient.writeBytes()
-
com.orientechnologies.orient.enterprise.channel.binary.OChannelBinaryClient.writeBytes()
-
com.sun.faban.harness.agent.FileService.writeBytes()
This method is responsible for writing to a file.
@param buffer to write
@param begin staring index
@param end ending index
@throws RemoteException A communications error occurred
@throws FileServiceException Error opening the file
-
com.sun.star.io.XOutputStream.writeBytes()
-
com.sun.star.io.XSequenceOutputStream.writeBytes()
-
com.trolltech.qt.core.QDataStream.writeBytes()
-
com.zwl.util.zip.impl.ExtZipOutputStream.writeBytes()
-
dovetaildb.bytes.Bytes.writeBytes()
-
io.airlift.slice.DynamicSliceOutput.writeBytes()
-
io.netty.buffer.ByteBuf.writeBytes()
Transfers the specified source buffer's data to this buffer starting at the current {@code writerIndex} until the source buffer becomesunreadable, and increases the {@code writerIndex} by the number ofthe transferred bytes. This method is basically same with {@link #writeBytes(ByteBuf,int,int)}, except that this method increases the {@code readerIndex} of the source buffer by the number ofthe transferred bytes while {@link #writeBytes(ByteBuf,int,int)}does not.
@throws IndexOutOfBoundsException if {@code src.readableBytes} is greater than{@code this.writableBytes}
-
io.netty.buffer.ChannelBuffer.writeBytes()
-
io.netty.buffer.DrillBuf.writeBytes()
-
java.io.DataOutput.writeBytes()
Writes a string to the output stream. For every character in the string
s
, taken in order, one byte is written to the output stream. If
s
is
null
, a
NullPointerException
is thrown.
If s.length
is zero, then no bytes are written. Otherwise, the character s[0]
is written first, then s[1]
, and so on; the last character written is s[s.length-1]
. For each character, one byte is written, the low-order byte, in exactly the manner of the writeByte
method . The high-order eight bits of each character in the string are ignored.
@param s the string of bytes to be written.
@throws IOException if an I/O error occurs.
-
java.io.DataOutputStream.writeBytes()
Writes the low order 8-bit bytes from a String to this output stream.
@param str the String containing the bytes to write to the OutputStream
@throws IOException If an error occurs attempting to write to this DataOutputStream.
@see DataInput#readFully(byte[])
@see DataInput#readFully(byte[],int,int)
-
java.io.RandomAccessFile.writeBytes()
Writes the low order 8-bit bytes from a String to this output stream.
@param str the String containing the bytes to write to the OutputStream
@throws IOException If an error occurs attempting to write to this DataOutputStream.
@see #read(byte[])
@see #read(byte[],int,int)
@see #readFully(byte[])
@see #readFully(byte[],int,int)
-
javax.jms.BytesMessage.writeBytes()
-
javax.jms.MapMessage.writeBytes()
-
javax.jms.Message.writeBytes()
-
javax.jms.ObjectMessage.writeBytes()
-
javax.jms.StreamMessage.writeBytes()
-
javax.jms.TextMessage.writeBytes()
-
net.gleamynode.netty.buffer.ChannelBuffer.writeBytes()
-
net.minecraft.util.io.netty.buffer.ByteBuf.writeBytes()
-
net.solosky.maplefetion.net.buffer.ByteArrayWriter.writeBytes()
-
net.solosky.maplefetion.net.buffer.ByteWriter.writeBytes()
写入一个字节数组
@param bytes
@param offset
@param len
-
net.timewalker.ffmq3.common.message.BytesMessageImpl.writeBytes()
-
net.timewalker.ffmq3.common.message.StreamMessageImpl.writeBytes()
-
org.activemq.message.ActiveMQBytesMessage.writeBytes()
Writes a byte array to the bytes message stream.
@param value the byte array 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.writeBytes()
Writes a byte array field to the stream message.
The byte array value
is written to the message as a byte array field. Consecutively written byte array fields are treated as two distinct fields when the fields are read.
@param value the byte array 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.writeBytes()
Writes a byte array to the bytes message stream.
@param value the byte array 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.writeBytes()
Writes a byte array field to the stream message.
The byte array value
is written to the message as a byte array field. Consecutively written byte array fields are treated as two distinct fields when the fields are read.
@param value the byte array 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.derby.impl.io.vfmem.BlockedByteArray.writeBytes()
Writes the given bytes into the blocked byte array.
@param pos the position to start writing at
@param buf the source buffer
@param offset the offset into the source buffer
@param len the number of bytes to write
@return The number of bytes written.
-
org.apache.directmemory.memory.buffer.MemoryBuffer.writeBytes()
-
org.apache.hadoop.fs.FSDataOutputStream.writeBytes()
-
org.apache.lucene.store.ByteArrayDataOutput.writeBytes()
-
org.apache.lucene.store.DataOutput.writeBytes()
Writes an array of bytes.
@param b the bytes to write
@param length the number of bytes to write
@see DataInput#readBytes(byte[],int,int)
-
org.apache.lucene.store.IndexOutput.writeBytes()
Writes an array of bytes.
@param b the bytes to write
@param length the number of bytes to write
@see IndexInput#readBytes(byte[],int,int)
-
org.apache.lucene.store.OutputStream.writeBytes()
Writes an array of bytes.
@param b the bytes to write
@param length the number of bytes to write
@see InputStream#readBytes(byte[],int,int)
-
org.apache.lucene.store.OutputStreamDataOutput.writeBytes()
-
org.apache.lucene.store.RAMOutputStream.writeBytes()
-
org.apache.lucene.util.PagedBytes.PagedBytesDataOutput.writeBytes()
-
org.apache.nutch.fs.NFSDataOutputStream.writeBytes()
-
org.apache.poi.hssf.record.formula.Ptg.writeBytes()
write this Ptg to a byte array
-
org.apache.qpid.client.message.JMSBytesMessage.writeBytes()
-
org.apache.qpid.client.message.JMSStreamMessage.writeBytes()
-
org.chromium.sdk.internal.websocket.ManualLoggingSocketWrapper.LoggableOutput.writeBytes()
-
org.codehaus.activemq.message.ActiveMQBytesMessage.writeBytes()
Writes a byte array to the bytes message stream.
@param value the byte array 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.writeBytes()
Writes a byte array field to the stream message.
The byte array value
is written to the message as a byte array field. Consecutively written byte array fields are treated as two distinct fields when the fields are read.
@param value the byte array 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.writeBytes()
-
org.elasticsearch.common.io.stream.StreamOutput.writeBytes()
Writes an array of bytes.
@param b the bytes to write
-
org.elasticsearch.common.netty.buffer.ChannelBuffer.writeBytes()
-
org.gephi.project.spi.WorkspaceBytesPersistenceProvider.writeBytes()
This is automatically called when saving a project file.
Your implementation must enclose all your data xml in a tag with the name provided in your getIdentifier
method.
@param writer XMLStreamWriter for xml serialization of this persistenceprovider data
@param workspace Current workspace being serialized
-
org.gridgain.grid.spi.indexing.h2.opt.GridLuceneOutputStream.writeBytes()
{@inheritDoc}
-
org.h2.value.Transfer.writeBytes()
Write a byte array.
@param data the value
@return itself
-
org.hornetq.api.core.HornetQBuffer.writeBytes()
Transfers the specified source buffer's data to this buffer starting at the current {@code writerIndex} and increases the {@code writerIndex}by the number of the transferred bytes (= {@code length}). This method is basically same with {@link #writeBytes(HornetQBuffer,int,int)}, except that this method increases the {@code readerIndex} of the sourcebuffer by the number of the transferred bytes (= {@code length}) while {@link #writeBytes(HornetQBuffer,int,int)} does not.
@param length the number of bytes to transfer
@throws IndexOutOfBoundsException if {@code length} is greater than {@code this.writableBytes} orif {@code length} is greater then {@code src.readableBytes}
-
org.hornetq.jms.client.HornetQStreamMessage.writeBytes()
-
org.hornetq.jms.tests.message.SimpleJMSBytesMessage.writeBytes()
-
org.hornetq.jms.tests.message.SimpleJMSStreamMessage.writeBytes()
-
org.iq80.leveldb.util.SliceOutput.writeBytes()
Transfers the specified source buffer's data to this buffer starting at the current {@code writerIndex} until the source buffer becomesunreadable, and increases the {@code writerIndex} by the number ofthe transferred bytes. This method is basically same with {@link #writeBytes(Slice,int,int)}, except that this method increases the {@code readerIndex} of the source buffer by the number ofthe transferred bytes while {@link #writeBytes(Slice,int,int)}does not.
@throws IndexOutOfBoundsException if {@code source.readableBytes} is greater than{@code this.writableBytes}
-
org.jboss.jms.message.JBossBytesMessage.writeBytes()
-
org.jboss.jms.message.JBossStreamMessage.writeBytes()
-
org.jboss.netty.buffer.BigEndianHeapChannelBuffer.writeBytes()
-
org.jboss.netty.buffer.ChannelBuffer.writeBytes()
Transfers the specified source buffer's data to this buffer starting at the current {@code writerIndex} until the source buffer becomesunreadable, and increases the {@code writerIndex} by the number ofthe transferred bytes. This method is basically same with {@link #writeBytes(ChannelBuffer,int,int)}, except that this method increases the {@code readerIndex} of the source buffer by the number ofthe transferred bytes while {@link #writeBytes(ChannelBuffer,int,int)}does not.
@throws IndexOutOfBoundsException if {@code src.readableBytes} is greater than{@code this.writableBytes}
-
org.jboss.netty.buffer.DynamicChannelBuffer.writeBytes()
-
org.jboss.remoting3.jmx.protocol.CancellableDataOutputStream.writeBytes()
-
org.jboss.remotingjmx.protocol.CancellableDataOutputStream.writeBytes()
-
org.jboss.test.messaging.jms.message.SimpleJMSBytesMessage.writeBytes()
-
org.jboss.test.messaging.jms.message.SimpleJMSStreamMessage.writeBytes()
-
org.jgroups.util.ByteArrayDataOutputStream.writeBytes()
-
org.lealone.value.Transfer.writeBytes()
Write a byte array.
@param data the value
@return itself
-
org.lilyproject.bytes.api.DataOutput.writeBytes()
Writes a byte[] to the DataOutput
-
org.lilyproject.bytes.impl.DataOutputImpl.writeBytes()
-
org.netbeans.lib.cvsclient.util.LoggedDataOutputStream.writeBytes()
-
org.xmlBlaster.jms.XBBytesMessage.writeBytes()
-
parquet.column.values.plain.PlainValuesWriter.writeBytes()
-
promauto.utils.RpSerialPort.writeBytes()
Writes an array of bytes to the output buffer
@param data
@return
-
streamer.ByteBuffer.writeBytes()
-
uk.ac.ucl.panda.utility.io.IndexOutput.writeBytes()
Writes an array of bytes.
@param b the bytes to write
@param length the number of bytes to write
@see IndexInput#readBytes(byte[],int,int)