ktor-io
Module Contents
alltypes
Module Contents
abstract class AbstractInput : Input
Module Contents
AbstractInput(head: IoBuffer = IoBuffer.Empty, remaining: Long = head.remainingAll(), pool: ObjectPool<ChunkBuffer> = ChunkBuffer.Pool)
AbstractInput(head: ChunkBuffer = ChunkBuffer.Empty, remaining: Long = head.remainingAll(), pool: ObjectPool<ChunkBuffer> = ChunkBuffer.Pool)
var byteOrder: ByteOrder
fun canRead(): Boolean
fun close(): Unit
protected abstract fun closeSource(): Unit
fun discard(n: Int): Int
fun discard(n: Long): Long
fun discardExact(n: Int): Unit
val endOfInput: Boolean
fun ensureNextHead(current: ChunkBuffer): ChunkBuffer?
protected abstract fun fill(destination: Memory, offset: Int, length: Int): Int
protected open fun fill(): ChunkBuffer?
fun fixGapAfterRead(current: ChunkBuffer): Unit
fun hasBytes(n: Int): Boolean
val isEmpty: Boolean
val isNotEmpty: Boolean
protected fun markNoMoreChunksAvailable(): Unit
fun peekTo(destination: Memory, destinationOffset: Long, offset: Long, min: Long, max: Long): Long
fun peekTo(buffer: IoBuffer): Int
val pool: ObjectPool<ChunkBuffer>
fun prepareReadHead(minSize: Int): ChunkBuffer?
fun readByte(): Byte
fun readDouble(): Double
fun readFloat(): Float
fun readFully(dst: ByteArray, offset: Int, length: Int): Unit
fun readInt(): Int
fun readLong(): Long
fun readShort(): Short
fun readText(out: Appendable, min: Int = 0, max: Int = Int.MAX_VALUE): Int
fun readText(min: Int = 0, max: Int = Int.MAX_VALUE): String
fun readTextExact(out: Appendable, exactCharacters: Int): Unit
fun readTextExact(exactCharacters: Int): String
fun release(): Unit
val remaining: Long
fun tryPeek(): Int
fun updateHeadRemaining(remaining: Int): Unit
abstract class AbstractOutput : Appendable, Output
open class Buffer
class BufferLimitExceededException : Exception
class ByteBufferPool : DefaultPool<ByteBuffer>
interface ByteChannel : ByteReadChannel, ByteWriteChannel
abstract class ByteChannelSequentialBase : ByteChannel, ByteReadChannel, ByteWriteChannel, SuspendableReadSession, HasReadSession, HasWriteSession
Module Contents
ByteChannelSequentialBase(initial: IoBuffer, autoFlush: Boolean)
ByteChannelSequentialBase(initial: IoBuffer, autoFlush: Boolean, pool: ObjectPool<ChunkBuffer> = ChunkBuffer.Pool)
protected fun afterRead(): Unit
protected fun afterRead(count: Int): Unit
protected fun afterWrite(): Unit
protected fun afterWrite(count: Int): Unit
open val autoFlush: Boolean
open val availableForRead: Int
open val availableForWrite: Int
open suspend fun await(atLeast: Int): Boolean
open suspend fun awaitFreeSpace(): Unit
protected suspend fun awaitSuspend(atLeast: Int): Boolean
open fun beginWriteSession(): WriterSuspendSession
open fun cancel(cause: Throwable?): Boolean
open fun close(cause: Throwable?): Boolean
protected var closed: Boolean
var closedCause: Throwable?
open fun discard(n: Int): Int
open suspend fun discard(max: Long): Long
open fun endReadSession(): Unit
open fun endWriteSession(written: Int): Unit
open fun flush(): Unit
open val isClosedForRead: Boolean
open val isClosedForWrite: Boolean
suspend fun peekTo(destination: Memory, destinationOffset: Long, offset: Long, min: Long, max: Long): Long
protected fun prepareFlushedBytes(): Unit
open suspend fun readAvailable(dst: IoBuffer): Int
open suspend fun readAvailable(dst: ByteArray, offset: Int, length: Int): Int
protected fun readAvailableClosed(): Int
open suspend fun readBoolean(): Boolean
open suspend fun readByte(): Byte
open var readByteOrder: ByteOrder
open suspend fun readDouble(): Double
open suspend fun readFloat(): Float
open suspend fun readFully(dst: IoBuffer, n: Int): Unit
open suspend fun readFully(dst: ByteArray, offset: Int, length: Int): Unit
open suspend fun readInt(): Int
open suspend fun readLong(): Long
open suspend fun readPacket(size: Int, : Int): ByteReadPacket
open suspend fun readRemaining(limit: Long, headerSizeHint: Int): ByteReadPacket
open fun readSession(consumer: ReadSession.() -> Unit): Unit
open suspend fun readShort(): Short
open suspend fun readSuspendableSession(consumer: suspend SuspendableReadSession.() -> Unit): Unit
open suspend fun readUTF8Line(limit: Int): String?
open suspend fun <A : Appendable> readUTF8LineTo(out: A, limit: Int): Boolean
protected val readable: ByteReadPacket
open fun request(atLeast: Int): IoBuffer?
open fun startReadSession(): SuspendableReadSession
open val totalBytesRead: Long
open val totalBytesWritten: Long
protected val writable: BytePacketBuilder
open suspend fun writeAvailable(src: IoBuffer): Int
open suspend fun writeAvailable(src: ByteArray, offset: Int, length: Int): Int
open suspend fun writeByte(b: Byte): Unit
open var writeByteOrder: ByteOrder
open suspend fun writeDouble(d: Double): Unit
open suspend fun writeFloat(f: Float): Unit
open suspend fun writeFully(src: IoBuffer): Unit
open suspend fun writeFully(src: Buffer): Unit
open suspend fun writeFully(src: ByteArray, offset: Int, length: Int): Unit
open suspend fun writeFully(memory: Memory, startIndex: Int, endIndex: Int): Unit
open suspend fun writeInt(i: Int): Unit
open suspend fun writeLong(l: Long): Unit
open suspend fun writePacket(packet: ByteReadPacket): Unit
open suspend fun writeShort(s: Short): Unit
open suspend fun writeSuspendSession(visitor: suspend WriterSuspendSession.() -> Unit): Unit
class ByteChannelSequentialJVM : ByteChannelSequentialBase
enum expect class ByteOrder
class BytePacketBuilder : BytePacketBuilderPlatformBase
abstract class BytePacketBuilderBase : AbstractOutput
abstract class BytePacketBuilderPlatformBase : BytePacketBuilderBase
expect interface ByteReadChannel
Module Contents
val Empty: ByteReadChannel
abstract val availableForRead: Int
abstract suspend fun awaitContent(): Unit
abstract fun cancel(cause: Throwable?): Boolean
open suspend fun consumeEachBufferRange(visitor: ConsumeEachBufferVisitor): Unit
abstract suspend fun discard(max: Long): Long
abstract val isClosedForRead: Boolean
abstract val isClosedForWrite: Boolean
abstract fun <R> lookAhead(visitor: LookAheadSession.() -> R): R
abstract suspend fun <R> lookAheadSuspend(visitor: suspend LookAheadSuspendSession.() -> R): R
abstract suspend fun peekTo(destination: Memory, destinationOffset: Long, offset: Long = 0, min: Long = 1, max: Long = Long.MAX_VALUE): Long
abstract suspend fun read(min: Int = 1, consumer: (ByteBuffer) -> Unit): Unit
abstract suspend fun readAvailable(dst: ByteArray, offset: Int, length: Int): Int
abstract suspend fun readAvailable(dst: IoBuffer): Int
abstract fun readAvailable(min: Int = 1, block: (ByteBuffer) -> Unit): Int
abstract suspend fun readAvailable(dst: ByteBuffer): Int
abstract suspend fun readBoolean(): Boolean
abstract suspend fun readByte(): Byte
abstract var readByteOrder: ByteOrder
abstract suspend fun readDouble(): Double
abstract suspend fun readFloat(): Float
abstract suspend fun readFully(dst: ByteArray, offset: Int, length: Int): Unit
abstract suspend fun readFully(dst: IoBuffer, n: Int): Unit
abstract suspend fun readFully(dst: ByteBuffer): Int
abstract suspend fun readInt(): Int
abstract suspend fun readLong(): Long
abstract suspend fun readPacket(size: Int, : Int): ByteReadPacket
abstract suspend fun readRemaining(limit: Long, headerSizeHint: Int): ByteReadPacket
abstract fun readSession(consumer: ReadSession.() -> Unit): Unit
abstract suspend fun readShort(): Short
abstract suspend fun readSuspendableSession(consumer: suspend SuspendableReadSession.() -> Unit): Unit
abstract suspend fun readUTF8Line(limit: Int): String?
abstract suspend fun <A : Appendable> readUTF8LineTo(out: A, limit: Int): Boolean
abstract val totalBytesRead: Long
class ByteReadPacket : ByteReadPacketPlatformBase, Input
abstract class ByteReadPacketBase : AbstractInput
abstract class ByteReadPacketPlatformBase : ByteReadPacketBase
expect interface ByteWriteChannel
typealias CancellationException = <ERROR CLASS>
expect object Charsets
open class ChunkBuffer : Buffer
expect interface Closeable
class ClosedWriteChannelException
typealias ConsumeEachBufferVisitor = (buffer: ByteBuffer, last: Boolean) -> Boolean
annotation class DangerousInternalIoApi
abstract expect class DefaultPool<T : Any> : ObjectPool<T>
class DirectByteBufferPool : DefaultPool<ByteBuffer>
expect class EOFException : IOException
open expect class EOFException : IOException
annotation class ExperimentalIoApi
open expect class IOException : Exception
expect interface Input : Closeable
Module Contents
abstract var byteOrder: ByteOrder
abstract fun close(): Unit
abstract fun discard(n: Long): Long
abstract val endOfInput: Boolean
abstract fun peekTo(destination: Memory, destinationOffset: Long, offset: Long = 0, min: Long = 1, max: Long = Long.MAX_VALUE): Long
open fun peekTo(buffer: IoBuffer): Int
open fun readAvailable(dst: ByteArray, offset: Int, length: Int): Int
open fun readAvailable(dst: ShortArray, offset: Int, length: Int): Int
open fun readAvailable(dst: IntArray, offset: Int, length: Int): Int
open fun readAvailable(dst: LongArray, offset: Int, length: Int): Int
open fun readAvailable(dst: FloatArray, offset: Int, length: Int): Int
open fun readAvailable(dst: DoubleArray, offset: Int, length: Int): Int
open fun readAvailable(dst: IoBuffer, length: Int): Int
open fun readAvailable(dst: ByteBuffer, length: Int = dst.remaining()): Int
abstract fun readByte(): Byte
open fun readDouble(): Double
open fun readFloat(): Float
open fun readFully(dst: ByteArray, offset: Int, length: Int): Unit
open fun readFully(dst: ShortArray, offset: Int, length: Int): Unit
open fun readFully(dst: IntArray, offset: Int, length: Int): Unit
open fun readFully(dst: LongArray, offset: Int, length: Int): Unit
open fun readFully(dst: FloatArray, offset: Int, length: Int): Unit
open fun readFully(dst: DoubleArray, offset: Int, length: Int): Unit
open fun readFully(dst: IoBuffer, length: Int): Unit
open fun readFully(dst: ByteBuffer, length: Int = dst.remaining()): Unit
open fun readInt(): Int
open fun readLong(): Long
open fun readShort(): Short
abstract fun tryPeek(): Int
class InsufficientSpaceException : Exception
expect class IoBuffer : Input, Output, ChunkBuffer
Module Contents
IoBuffer(memory: Memory, origin: ChunkBuffer?)
IoBuffer(external: ByteBuffer)
val Empty: IoBuffer
val EmptyPool: ObjectPool<IoBuffer>
val NoPool: ObjectPool<IoBuffer>
val Pool: ObjectPool<IoBuffer>
val ReservedSize: Int
fun append(csq: CharSequence?, start: Int, end: Int): Appendable
fun append(csq: CharSequence?): Appendable
fun append(csq: CharArray, start: Int, end: Int): Appendable
fun append(c: Char): Appendable
fun appendChars(csq: CharArray, start: Int, end: Int): Int
fun appendChars(csq: CharSequence, start: Int, end: Int): Int
var byteOrder: ByteOrder
fun canRead(): Boolean
fun canWrite(): Boolean
fun close(): Unit
fun duplicate(): IoBuffer
val endOfInput: Boolean
fun fill(n: Long, v: Byte): Unit
fun flush(): Unit
fun getNext(): IoBuffer?
fun isExclusivelyOwned(): Boolean
fun makeView(): IoBuffer
fun peekTo(destination: Memory, destinationOffset: Long, offset: Long, min: Long, max: Long): Long
fun peekTo(buffer: IoBuffer): Int
fun pushBack(n: Int): Unit
fun read(dst: ByteBuffer, size: Int): Unit
fun read(dst: ByteArray, offset: Int, length: Int): Unit
fun readAvailable(dst: ByteArray, offset: Int, length: Int): Int
fun readAvailable(dst: IoBuffer, length: Int): Int
fun readAvailable(dst: ShortArray, offset: Int, length: Int): Int
fun readAvailable(dst: IntArray, offset: Int, length: Int): Int
fun readAvailable(dst: LongArray, offset: Int, length: Int): Int
fun readAvailable(dst: FloatArray, offset: Int, length: Int): Int
fun readAvailable(dst: DoubleArray, offset: Int, length: Int): Int
fun readAvailable(dst: ByteBuffer, length: Int): Int
inline fun readDirect(block: (ByteBuffer) -> Unit): Int
fun readDouble(): Double
fun readFloat(): Float
fun readFully(dst: ByteArray, offset: Int, length: Int): Unit
fun readFully(dst: IoBuffer, length: Int): Unit
fun readFully(dst: ShortArray, offset: Int, length: Int): Unit
fun readFully(dst: IntArray, offset: Int, length: Int): Unit
fun readFully(dst: LongArray, offset: Int, length: Int): Unit
fun readFully(dst: DoubleArray, offset: Int, length: Int): Unit
fun readFully(dst: FloatArray, offset: Int, length: Int): Unit
fun readFully(dst: ByteBuffer, length: Int): Unit
fun readInt(): Int
fun readLong(): Long
fun readShort(): Short
fun readText(decoder: CharsetDecoder, out: Appendable, lastBuffer: Boolean, max: Int = Int.MAX_VALUE): Int
fun release(pool: ObjectPool<IoBuffer>): Unit
fun resetFromContentToWrite(child: ByteBuffer): Unit
fun setNext(newNext: IoBuffer?): Unit
fun toString(): String
fun tryPeek(): Int
fun write(src: ByteBuffer): Unit
fun write(src: ByteArray, offset: Int, length: Int): Unit
fun writeBuffer(src: IoBuffer, length: Int): Int
inline fun writeDirect(size: Int, block: (ByteBuffer) -> Unit): Int
fun writeDouble(v: Double): Unit
fun writeFloat(v: Float): Unit
fun writeFully(src: ByteArray, offset: Int, length: Int): Unit
fun writeFully(src: ShortArray, offset: Int, length: Int): Unit
fun writeFully(src: IntArray, offset: Int, length: Int): Unit
fun writeFully(src: LongArray, offset: Int, length: Int): Unit
fun writeFully(src: FloatArray, offset: Int, length: Int): Unit
fun writeFully(src: DoubleArray, offset: Int, length: Int): Unit
fun writeFully(src: IoBuffer, length: Int): Unit
fun writeFully(bb: ByteBuffer): Unit
fun writeInt(v: Int): Unit
fun writeLong(v: Long): Unit
fun writeShort(v: Short): Unit
interface LookAheadSession
interface LookAheadSuspendSession : LookAheadSession
open expect class MalformedInputException : Throwable
class MalformedUTF8InputException : Exception
expect class Memory
Module Contents
Memory(buffer: ByteBuffer)
val Empty: Memory
val buffer: ByteBuffer
fun copyTo(destination: Memory, offset: Int, length: Int, destinationOffset: Int): Unit
fun copyTo(destination: Memory, offset: Long, length: Long, destinationOffset: Long): Unit
inline fun loadAt(index: Int): Byte
inline fun loadAt(index: Long): Byte
val size: Long
val size32: Int
fun slice(offset: Int, length: Int): Memory
fun slice(offset: Long, length: Long): Memory
inline fun storeAt(index: Int, value: Byte): Unit
inline fun storeAt(index: Long, value: Byte): Unit
abstract class NoPoolImpl<T : Any> : ObjectPool<T>
interface ObjectPool<T : Any> : Closeable
expect interface Output : Appendable, Closeable
Module Contents
abstract fun append(csq: CharArray, start: Int, end: Int): Appendable
abstract var byteOrder: ByteOrder
abstract fun close(): Unit
open fun fill(n: Long, v: Byte): Unit
abstract fun flush(): Unit
abstract fun writeByte(v: Byte): Unit
open fun writeDouble(v: Double): Unit
open fun writeFloat(v: Float): Unit
open fun writeFully(src: ByteArray, offset: Int, length: Int): Unit
open fun writeFully(src: ShortArray, offset: Int, length: Int): Unit
open fun writeFully(src: IntArray, offset: Int, length: Int): Unit
open fun writeFully(src: LongArray, offset: Int, length: Int): Unit
open fun writeFully(src: FloatArray, offset: Int, length: Int): Unit
open fun writeFully(src: DoubleArray, offset: Int, length: Int): Unit
open fun writeFully(src: IoBuffer, length: Int): Unit
open fun writeFully(bb: ByteBuffer): Unit
open fun writeInt(v: Int): Unit
open fun writeLong(v: Long): Unit
open fun writeShort(v: Short): Unit
interface ReadSession
interface ReaderJob : Job
interface ReaderScope : CoroutineScope
abstract class SingleInstancePool<T : Any> : ObjectPool<T>
interface SuspendableReadSession : ReadSession
class TooLongLineException : MalformedInputException
interface WriterJob : Job
interface WriterScope : CoroutineScope
interface WriterSession
interface WriterSuspendSession : WriterSession
java.io.InputStream
java.io.InputStream
java.io.OutputStream
java.nio.ByteBuffer
java.nio.ByteBuffer
java.nio.channels.Pipe
java.nio.channels.ReadableByteChannel
java.nio.channels.ReadableByteChannel
java.nio.channels.WritableByteChannel
java.nio.charset.Charset
java.nio.charset.CharsetDecoder
java.nio.charset.CharsetEncoder
Module Contents
expect val CharsetEncoder.charset: Charset
fun CharsetEncoder.encode(input: CharSequence, fromIndex: Int, toIndex: Int, dst: Output): Unit
fun CharsetEncoder.encode(input: CharSequence, fromIndex: Int = 0, toIndex: Int = input.length): ByteReadPacket
fun CharsetEncoder.encode(input: CharArray, fromIndex: Int, toIndex: Int, dst: Output): Unit
expect fun CharsetEncoder.encodeToByteArray(input: CharSequence, fromIndex: Int = 0, toIndex: Int = input.length): ByteArray
fun CharsetEncoder.encodeToByteArrayImpl(input: CharSequence, fromIndex: Int = 0, toIndex: Int = input.length): ByteArray
expect fun CharsetEncoder.encodeUTF8(input: ByteReadPacket, dst: Output): Unit
fun CharsetEncoder.encodeUTF8(input: ByteReadPacket): ByteReadPacket
kotlin.Any
kotlin.ByteArray
kotlin.Double
kotlin.Float
kotlin.Int
kotlin.Long
kotlin.Short
kotlin.String
kotlin.Throwable
kotlinx.coroutines.CoroutineScope
package io.ktor.utils.io
Module Contents
interface ByteChannel : ByteReadChannel, ByteWriteChannel
expect fun ByteChannel(autoFlush: Boolean = false): ByteChannel
fun ByteChannel(autoFlush: Boolean = false, exceptionMapper: (Throwable?) -> Throwable?): ByteChannel
abstract class ByteChannelSequentialBase : ByteChannel, ByteReadChannel, ByteWriteChannel, SuspendableReadSession, HasReadSession, HasWriteSession
Module Contents
ByteChannelSequentialBase(initial: IoBuffer, autoFlush: Boolean)
ByteChannelSequentialBase(initial: IoBuffer, autoFlush: Boolean, pool: ObjectPool<ChunkBuffer> = ChunkBuffer.Pool)
protected fun afterRead(): Unit
protected fun afterRead(count: Int): Unit
protected fun afterWrite(): Unit
protected fun afterWrite(count: Int): Unit
open val autoFlush: Boolean
open val availableForRead: Int
open val availableForWrite: Int
open suspend fun await(atLeast: Int): Boolean
open suspend fun awaitFreeSpace(): Unit
protected suspend fun awaitSuspend(atLeast: Int): Boolean
open fun beginWriteSession(): WriterSuspendSession
open fun cancel(cause: Throwable?): Boolean
open fun close(cause: Throwable?): Boolean
protected var closed: Boolean
var closedCause: Throwable?
open fun discard(n: Int): Int
open suspend fun discard(max: Long): Long
open fun endReadSession(): Unit
open fun endWriteSession(written: Int): Unit
open fun flush(): Unit
open val isClosedForRead: Boolean
open val isClosedForWrite: Boolean
suspend fun peekTo(destination: Memory, destinationOffset: Long, offset: Long, min: Long, max: Long): Long
protected fun prepareFlushedBytes(): Unit
open suspend fun readAvailable(dst: IoBuffer): Int
open suspend fun readAvailable(dst: ByteArray, offset: Int, length: Int): Int
protected fun readAvailableClosed(): Int
open suspend fun readBoolean(): Boolean
open suspend fun readByte(): Byte
open var readByteOrder: ByteOrder
open suspend fun readDouble(): Double
open suspend fun readFloat(): Float
open suspend fun readFully(dst: IoBuffer, n: Int): Unit
open suspend fun readFully(dst: ByteArray, offset: Int, length: Int): Unit
open suspend fun readInt(): Int
open suspend fun readLong(): Long
open suspend fun readPacket(size: Int, : Int): ByteReadPacket
open suspend fun readRemaining(limit: Long, headerSizeHint: Int): ByteReadPacket
open fun readSession(consumer: ReadSession.() -> Unit): Unit
open suspend fun readShort(): Short
open suspend fun readSuspendableSession(consumer: suspend SuspendableReadSession.() -> Unit): Unit
open suspend fun readUTF8Line(limit: Int): String?
open suspend fun <A : Appendable> readUTF8LineTo(out: A, limit: Int): Boolean
protected val readable: ByteReadPacket
open fun request(atLeast: Int): IoBuffer?
open fun startReadSession(): SuspendableReadSession
open val totalBytesRead: Long
open val totalBytesWritten: Long
protected val writable: BytePacketBuilder
open suspend fun writeAvailable(src: IoBuffer): Int
open suspend fun writeAvailable(src: ByteArray, offset: Int, length: Int): Int
open suspend fun writeByte(b: Byte): Unit
open var writeByteOrder: ByteOrder
open suspend fun writeDouble(d: Double): Unit
open suspend fun writeFloat(f: Float): Unit
open suspend fun writeFully(src: IoBuffer): Unit
open suspend fun writeFully(src: Buffer): Unit
open suspend fun writeFully(src: ByteArray, offset: Int, length: Int): Unit
open suspend fun writeFully(memory: Memory, startIndex: Int, endIndex: Int): Unit
open suspend fun writeInt(i: Int): Unit
open suspend fun writeLong(l: Long): Unit
open suspend fun writePacket(packet: ByteReadPacket): Unit
open suspend fun writeShort(s: Short): Unit
open suspend fun writeSuspendSession(visitor: suspend WriterSuspendSession.() -> Unit): Unit
class ByteChannelSequentialJVM : ByteChannelSequentialBase
fun ByteReadChannel(content: ByteArray): ByteReadChannel
fun ByteReadChannel(content: ByteArray, offset: Int): ByteReadChannel
expect fun ByteReadChannel(content: ByteArray, offset: Int, length: Int): ByteReadChannel
fun ByteReadChannel(text: String, charset: Charset = Charsets.UTF_8): ByteReadChannel
fun ByteReadChannel(content: ByteBuffer): ByteReadChannel
expect interface ByteReadChannel
Module Contents
val Empty: ByteReadChannel
abstract val availableForRead: Int
abstract suspend fun awaitContent(): Unit
abstract fun cancel(cause: Throwable?): Boolean
open suspend fun consumeEachBufferRange(visitor: ConsumeEachBufferVisitor): Unit
abstract suspend fun discard(max: Long): Long
abstract val isClosedForRead: Boolean
abstract val isClosedForWrite: Boolean
abstract fun <R> lookAhead(visitor: LookAheadSession.() -> R): R
abstract suspend fun <R> lookAheadSuspend(visitor: suspend LookAheadSuspendSession.() -> R): R
abstract suspend fun peekTo(destination: Memory, destinationOffset: Long, offset: Long = 0, min: Long = 1, max: Long = Long.MAX_VALUE): Long
abstract suspend fun read(min: Int = 1, consumer: (ByteBuffer) -> Unit): Unit
abstract suspend fun readAvailable(dst: ByteArray, offset: Int, length: Int): Int
abstract suspend fun readAvailable(dst: IoBuffer): Int
abstract fun readAvailable(min: Int = 1, block: (ByteBuffer) -> Unit): Int
abstract suspend fun readAvailable(dst: ByteBuffer): Int
abstract suspend fun readBoolean(): Boolean
abstract suspend fun readByte(): Byte
abstract var readByteOrder: ByteOrder
abstract suspend fun readDouble(): Double
abstract suspend fun readFloat(): Float
abstract suspend fun readFully(dst: ByteArray, offset: Int, length: Int): Unit
abstract suspend fun readFully(dst: IoBuffer, n: Int): Unit
abstract suspend fun readFully(dst: ByteBuffer): Int
abstract suspend fun readInt(): Int
abstract suspend fun readLong(): Long
abstract suspend fun readPacket(size: Int, : Int): ByteReadPacket
abstract suspend fun readRemaining(limit: Long, headerSizeHint: Int): ByteReadPacket
abstract fun readSession(consumer: ReadSession.() -> Unit): Unit
abstract suspend fun readShort(): Short
abstract suspend fun readSuspendableSession(consumer: suspend SuspendableReadSession.() -> Unit): Unit
abstract suspend fun readUTF8Line(limit: Int): String?
abstract suspend fun <A : Appendable> readUTF8LineTo(out: A, limit: Int): Boolean
abstract val totalBytesRead: Long
expect interface ByteWriteChannel
typealias CancellationException = <ERROR CLASS>
class ClosedWriteChannelException
typealias ConsumeEachBufferVisitor = (buffer: ByteBuffer, last: Boolean) -> Boolean
val EmptyByteReadChannel: ByteReadChannel
interface LookAheadSession
interface LookAheadSuspendSession : LookAheadSession
interface ReadSession
interface ReaderJob : Job
interface ReaderScope : CoroutineScope
interface SuspendableReadSession : ReadSession
interface WriterJob : Job
interface WriterScope : CoroutineScope
interface WriterSession
interface WriterSuspendSession : WriterSession
fun ByteReadChannel.cancel(): Boolean
fun ByteWriteChannel.close(): Boolean
inline suspend fun ByteReadChannel.consumeEachBufferRange(visitor: ConsumeEachBufferVisitor): Unit
inline fun LookAheadSession.consumeEachRemaining(visitor: (ByteBuffer) -> Boolean): Unit
inline suspend fun LookAheadSuspendSession.consumeEachRemaining(visitor: suspend (ByteBuffer) -> Boolean): Unit
suspend fun ByteReadChannel.copyAndClose(dst: ByteWriteChannel, limit: Long = Long.MAX_VALUE): Long
suspend fun ByteChannelSequentialBase.copyTo(dst: ByteChannelSequentialBase, limit: Long = Long.MAX_VALUE): Long
suspend fun ByteReadChannel.copyTo(dst: ByteWriteChannel): Long
suspend expect fun ByteReadChannel.copyTo(dst: ByteWriteChannel, limit: Long): Long
suspend fun ByteReadChannel.discard(): Long
inline suspend fun ByteReadChannel.discardExact(n: Long): Unit
suspend fun ByteChannelSequentialBase.joinTo(dst: ByteChannelSequentialBase, closeOnEnd: Boolean): Unit
suspend expect fun ByteReadChannel.joinTo(dst: ByteWriteChannel, closeOnEnd: Boolean): Unit
kotlin.Any
kotlin.Throwable
kotlinx.coroutines.CoroutineScope
inline suspend fun ByteReadChannel.read(desiredSize: Int = 1, block: (source: Memory, start: Long, endExclusive: Long) -> Int): Int
suspend fun ByteReadChannel.readAvailable(dst: ByteArray): Int
inline suspend fun ByteReadChannel.readDouble(byteOrder: ByteOrder): Double
inline suspend fun ByteReadChannel.readDoubleLittleEndian(): Double
inline suspend fun ByteReadChannel.readFloat(byteOrder: ByteOrder): Float
inline suspend fun ByteReadChannel.readFloatLittleEndian(): Float
suspend fun ByteReadChannel.readFully(dst: IoBuffer): Unit
suspend fun ByteReadChannel.readFully(dst: ByteArray): Unit
inline suspend fun ByteReadChannel.readInt(byteOrder: ByteOrder): Int
inline suspend fun ByteReadChannel.readIntLittleEndian(): Int
inline suspend fun ByteReadChannel.readLong(byteOrder: ByteOrder): Long
inline suspend fun ByteReadChannel.readLongLittleEndian(): Long
suspend fun ByteReadChannel.readPacket(size: Int): ByteReadPacket
suspend fun ByteReadChannel.readRemaining(limit: Long): ByteReadPacket
suspend fun ByteReadChannel.readRemaining(): ByteReadPacket
inline suspend fun ByteReadChannel.readShort(byteOrder: ByteOrder): Short
inline suspend fun ByteReadChannel.readShortLittleEndian(): Short
suspend fun ByteReadChannel.readUTF8Line(): String?
suspend fun ByteReadChannel.readUTF8LineTo(out: Appendable): Boolean
suspend fun ByteReadChannel.readUntilDelimiter(delimiter: ByteBuffer, dst: ByteBuffer): Int
fun reader(coroutineContext: <ERROR CLASS>, channel: ByteChannel, parent: Job? = null, block: suspend ReaderScope.() -> Unit): ReaderJob
fun reader(coroutineContext: <ERROR CLASS>, autoFlush: Boolean = false, parent: Job? = null, block: suspend ReaderScope.() -> Unit): ReaderJob
suspend fun ByteReadChannel.skipDelimiter(delimiter: ByteBuffer): Unit
fun <E : Throwable> tryCopyException(exception: E, cause: Throwable): E?
inline suspend fun ByteWriteChannel.write(desiredSpace: Int = 1, block: (freeSpace: Memory, startOffset: Long, endExclusive: Long) -> Int): Int
suspend fun ByteWriteChannel.writeAvailable(src: ByteArray): Int
suspend fun ByteWriteChannel.writeBoolean(b: Boolean): Unit
suspend fun ByteWriteChannel.writeByte(b: Int): Unit
suspend fun ByteWriteChannel.writeChar(ch: Char): Unit
suspend fun ByteWriteChannel.writeDouble(value: Double, byteOrder: ByteOrder): Unit
suspend fun ByteWriteChannel.writeDoubleLittleEndian(value: Double): Unit
suspend fun ByteWriteChannel.writeFloat(value: Float, byteOrder: ByteOrder): Unit
suspend fun ByteWriteChannel.writeFloatLittleEndian(value: Float): Unit
suspend fun ByteWriteChannel.writeFully(src: ByteArray): Unit
suspend fun ByteWriteChannel.writeInt(i: Long): Unit
suspend fun ByteWriteChannel.writeInt(i: Long, byteOrder: ByteOrder): Unit
suspend fun ByteWriteChannel.writeInt(value: Int, byteOrder: ByteOrder): Unit
suspend fun ByteWriteChannel.writeIntLittleEndian(value: Int): Unit
suspend fun ByteWriteChannel.writeLong(value: Long, byteOrder: ByteOrder): Unit
suspend fun ByteWriteChannel.writeLongLittleEndian(value: Long): Unit
inline suspend fun ByteWriteChannel.writePacket(: Int = 0, builder: BytePacketBuilder.() -> Unit): Unit
suspend fun ByteWriteChannel.writePacketSuspend(builder: suspend BytePacketBuilder.() -> Unit): Unit
suspend fun ByteWriteChannel.writeShort(s: Int): Unit
suspend fun ByteWriteChannel.writeShort(s: Int, byteOrder: ByteOrder): Unit
suspend fun ByteWriteChannel.writeShort(value: Short, byteOrder: ByteOrder): Unit
suspend fun ByteWriteChannel.writeShortLittleEndian(value: Short): Unit
suspend fun ByteWriteChannel.writeStringUtf8(s: CharSequence): Unit
suspend fun ByteWriteChannel.writeStringUtf8(s: String): Unit
fun writer(coroutineContext: <ERROR CLASS>, channel: ByteChannel, parent: Job? = null, block: suspend WriterScope.() -> Unit): WriterJob
fun writer(coroutineContext: <ERROR CLASS>, autoFlush: Boolean = false, parent: Job? = null, block: suspend WriterScope.() -> Unit): WriterJob
package io.ktor.utils.io.bits
Module Contents
expect class Memory
Module Contents
Memory(buffer: ByteBuffer)
val Empty: Memory
val buffer: ByteBuffer
fun copyTo(destination: Memory, offset: Int, length: Int, destinationOffset: Int): Unit
fun copyTo(destination: Memory, offset: Long, length: Long, destinationOffset: Long): Unit
inline fun loadAt(index: Int): Byte
inline fun loadAt(index: Long): Byte
val size: Long
val size32: Int
fun slice(offset: Int, length: Int): Memory
fun slice(offset: Long, length: Long): Memory
inline fun storeAt(index: Int, value: Byte): Unit
inline fun storeAt(index: Long, value: Byte): Unit
fun Memory.copyTo(destination: ByteArray, offset: Int, length: Int): Unit
expect fun Memory.copyTo(destination: ByteArray, offset: Int, length: Int, destinationOffset: Int): Unit
fun Memory.copyTo(destination: ByteArray, offset: Long, length: Int): Unit
expect fun Memory.copyTo(destination: ByteArray, offset: Long, length: Int, destinationOffset: Int): Unit
fun Memory.copyTo(destination: ByteBuffer, offset: Int): Unit
fun Memory.copyTo(destination: ByteBuffer, offset: Long): Unit
expect fun Memory.fill(offset: Long, count: Long, value: Byte): Unit
expect fun Memory.fill(offset: Int, count: Int, value: Byte): Unit
inline operator fun Memory.get(index: Int): Byte
inline operator fun Memory.get(index: Long): Byte
java.nio.ByteBuffer
kotlin.ByteArray
kotlin.Double
kotlin.Float
kotlin.Int
kotlin.Long
kotlin.Short
inline fun Memory.loadByteArray(offset: Int, destination: ByteArray, destinationOffset: Int = 0, count: Int = destination.size - destinationOffset): Unit
inline fun Memory.loadByteArray(offset: Long, destination: ByteArray, destinationOffset: Int = 0, count: Int = destination.size - destinationOffset): Unit
expect fun Memory.loadDoubleArray(offset: Int, destination: DoubleArray, destinationOffset: Int = 0, count: Int = destination.size - destinationOffset): Unit
expect fun Memory.loadDoubleArray(offset: Long, destination: DoubleArray, destinationOffset: Int = 0, count: Int = destination.size - destinationOffset): Unit
inline expect fun Memory.loadDoubleAt(offset: Int): Double
inline expect fun Memory.loadDoubleAt(offset: Long): Double
expect fun Memory.loadFloatArray(offset: Int, destination: FloatArray, destinationOffset: Int = 0, count: Int = destination.size - destinationOffset): Unit
expect fun Memory.loadFloatArray(offset: Long, destination: FloatArray, destinationOffset: Int = 0, count: Int = destination.size - destinationOffset): Unit
inline expect fun Memory.loadFloatAt(offset: Int): Float
inline expect fun Memory.loadFloatAt(offset: Long): Float
expect fun Memory.loadIntArray(offset: Int, destination: IntArray, destinationOffset: Int = 0, count: Int = destination.size - destinationOffset): Unit
expect fun Memory.loadIntArray(offset: Long, destination: IntArray, destinationOffset: Int = 0, count: Int = destination.size - destinationOffset): Unit
inline expect fun Memory.loadIntAt(offset: Int): Int
inline expect fun Memory.loadIntAt(offset: Long): Int
expect fun Memory.loadLongArray(offset: Int, destination: LongArray, destinationOffset: Int = 0, count: Int = destination.size - destinationOffset): Unit
expect fun Memory.loadLongArray(offset: Long, destination: LongArray, destinationOffset: Int = 0, count: Int = destination.size - destinationOffset): Unit
inline expect fun Memory.loadLongAt(offset: Int): Long
inline expect fun Memory.loadLongAt(offset: Long): Long
expect fun Memory.loadShortArray(offset: Int, destination: ShortArray, destinationOffset: Int = 0, count: Int = destination.size - destinationOffset): Unit
expect fun Memory.loadShortArray(offset: Long, destination: ShortArray, destinationOffset: Int = 0, count: Int = destination.size - destinationOffset): Unit
inline expect fun Memory.loadShortAt(offset: Int): Short
inline expect fun Memory.loadShortAt(offset: Long): Short
inline fun Memory.loadUByteArray(offset: Int, destination: <ERROR CLASS>, destinationOffset: Int = 0, count: Int = destination.size - destinationOffset): Unit
inline fun Memory.loadUByteArray(offset: Long, destination: <ERROR CLASS>, destinationOffset: Int = 0, count: Int = destination.size - destinationOffset): Unit
inline fun Memory.loadUIntArray(offset: Int, destination: <ERROR CLASS>, destinationOffset: Int = 0, count: Int = destination.size - destinationOffset): Unit
inline fun Memory.loadUIntArray(offset: Long, destination: <ERROR CLASS>, destinationOffset: Int = 0, count: Int = destination.size - destinationOffset): Unit
inline fun Memory.loadUIntAt(offset: Int): <ERROR CLASS>
inline fun Memory.loadUIntAt(offset: Long): <ERROR CLASS>
inline fun Memory.loadULongArray(offset: Int, destination: <ERROR CLASS>, destinationOffset: Int = 0, count: Int = destination.size - destinationOffset): Unit
inline fun Memory.loadULongArray(offset: Long, destination: <ERROR CLASS>, destinationOffset: Int = 0, count: Int = destination.size - destinationOffset): Unit
inline fun Memory.loadULongAt(offset: Int): <ERROR CLASS>
inline fun Memory.loadULongAt(offset: Long): <ERROR CLASS>
inline fun Memory.loadUShortArray(offset: Int, destination: <ERROR CLASS>, destinationOffset: Int = 0, count: Int = destination.size - destinationOffset): Unit
inline fun Memory.loadUShortArray(offset: Long, destination: <ERROR CLASS>, destinationOffset: Int = 0, count: Int = destination.size - destinationOffset): Unit
inline fun Memory.loadUShortAt(offset: Int): <ERROR CLASS>
inline fun Memory.loadUShortAt(offset: Long): <ERROR CLASS>
inline fun Memory.Companion.of(array: ByteArray, offset: Int = 0, length: Int = array.size - offset): Memory
inline fun Memory.Companion.of(buffer: ByteBuffer): Memory
@ExperimentalUnsignedTypes fun <ERROR CLASS>.reverseByteOrder(): <ERROR CLASS>
inline operator fun Memory.set(index: Long, value: Byte): Unit
inline operator fun Memory.set(index: Int, value: Byte): Unit
inline fun Memory.storeAt(index: Long, value: <ERROR CLASS>): Unit
inline fun Memory.storeAt(index: Int, value: <ERROR CLASS>): Unit
inline fun Memory.storeByteArray(offset: Int, source: ByteArray, sourceOffset: Int = 0, count: Int = source.size - sourceOffset): Unit
inline fun Memory.storeByteArray(offset: Long, source: ByteArray, sourceOffset: Int = 0, count: Int = source.size - sourceOffset): Unit
expect fun Memory.storeDoubleArray(offset: Int, source: DoubleArray, sourceOffset: Int = 0, count: Int = source.size - sourceOffset): Unit
expect fun Memory.storeDoubleArray(offset: Long, source: DoubleArray, sourceOffset: Int = 0, count: Int = source.size - sourceOffset): Unit
inline expect fun Memory.storeDoubleAt(offset: Int, value: Double): Unit
inline expect fun Memory.storeDoubleAt(offset: Long, value: Double): Unit
expect fun Memory.storeFloatArray(offset: Int, source: FloatArray, sourceOffset: Int = 0, count: Int = source.size - sourceOffset): Unit
expect fun Memory.storeFloatArray(offset: Long, source: FloatArray, sourceOffset: Int = 0, count: Int = source.size - sourceOffset): Unit
inline expect fun Memory.storeFloatAt(offset: Int, value: Float): Unit
inline expect fun Memory.storeFloatAt(offset: Long, value: Float): Unit
expect fun Memory.storeIntArray(offset: Int, source: IntArray, sourceOffset: Int = 0, count: Int = source.size - sourceOffset): Unit
expect fun Memory.storeIntArray(offset: Long, source: IntArray, sourceOffset: Int = 0, count: Int = source.size - sourceOffset): Unit
inline expect fun Memory.storeIntAt(offset: Int, value: Int): Unit
inline expect fun Memory.storeIntAt(offset: Long, value: Int): Unit
expect fun Memory.storeLongArray(offset: Int, source: LongArray, sourceOffset: Int = 0, count: Int = source.size - sourceOffset): Unit
expect fun Memory.storeLongArray(offset: Long, source: LongArray, sourceOffset: Int = 0, count: Int = source.size - sourceOffset): Unit
inline expect fun Memory.storeLongAt(offset: Int, value: Long): Unit
inline expect fun Memory.storeLongAt(offset: Long, value: Long): Unit
expect fun Memory.storeShortArray(offset: Int, source: ShortArray, sourceOffset: Int = 0, count: Int = source.size - sourceOffset): Unit
expect fun Memory.storeShortArray(offset: Long, source: ShortArray, sourceOffset: Int = 0, count: Int = source.size - sourceOffset): Unit
inline expect fun Memory.storeShortAt(offset: Int, value: Short): Unit
inline expect fun Memory.storeShortAt(offset: Long, value: Short): Unit
inline fun Memory.storeUByteArray(offset: Int, source: <ERROR CLASS>, sourceOffset: Int = 0, count: Int = source.size - sourceOffset): Unit
inline fun Memory.storeUByteArray(offset: Long, source: <ERROR CLASS>, sourceOffset: Int = 0, count: Int = source.size - sourceOffset): Unit
inline fun Memory.storeUIntArray(offset: Int, source: <ERROR CLASS>, sourceOffset: Int = 0, count: Int = source.size - sourceOffset): Unit
inline fun Memory.storeUIntArray(offset: Long, source: <ERROR CLASS>, sourceOffset: Int = 0, count: Int = source.size - sourceOffset): Unit
inline fun Memory.storeUIntAt(offset: Int, value: <ERROR CLASS>): Unit
inline fun Memory.storeUIntAt(offset: Long, value: <ERROR CLASS>): Unit
inline fun Memory.storeULongArray(offset: Int, source: <ERROR CLASS>, sourceOffset: Int = 0, count: Int = source.size - sourceOffset): Unit
inline fun Memory.storeULongArray(offset: Long, source: <ERROR CLASS>, sourceOffset: Int = 0, count: Int = source.size - sourceOffset): Unit
inline fun Memory.storeULongAt(offset: Int, value: <ERROR CLASS>): Unit
inline fun Memory.storeULongAt(offset: Long, value: <ERROR CLASS>): Unit
inline fun Memory.storeUShortArray(offset: Int, source: <ERROR CLASS>, sourceOffset: Int = 0, count: Int = source.size - sourceOffset): Unit
inline fun Memory.storeUShortArray(offset: Long, source: <ERROR CLASS>, sourceOffset: Int = 0, count: Int = source.size - sourceOffset): Unit
inline fun Memory.storeUShortAt(offset: Int, value: <ERROR CLASS>): Unit
inline fun Memory.storeUShortAt(offset: Long, value: <ERROR CLASS>): Unit
inline fun <R> withMemory(size: Int, block: (Memory) -> R): R
inline fun <R> withMemory(size: Long, block: (Memory) -> R): R
package io.ktor.utils.io.charsets
Module Contents
Charset
CharsetDecoder
CharsetEncoder
expect object Charsets
open expect class MalformedInputException : Throwable
class TooLongLineException : MalformedInputException
fun decodeUtf8Result(numberOfChars: Int, requireBytes: Int): Long
fun decodeUtf8ResultCombine(prev: Long, next: Long): Long
java.nio.ByteBuffer
java.nio.charset.Charset
java.nio.charset.CharsetDecoder
java.nio.charset.CharsetEncoder
Module Contents
expect val CharsetEncoder.charset: Charset
fun CharsetEncoder.encode(input: CharSequence, fromIndex: Int, toIndex: Int, dst: Output): Unit
fun CharsetEncoder.encode(input: CharSequence, fromIndex: Int = 0, toIndex: Int = input.length): ByteReadPacket
fun CharsetEncoder.encode(input: CharArray, fromIndex: Int, toIndex: Int, dst: Output): Unit
expect fun CharsetEncoder.encodeToByteArray(input: CharSequence, fromIndex: Int = 0, toIndex: Int = input.length): ByteArray
fun CharsetEncoder.encodeToByteArrayImpl(input: CharSequence, fromIndex: Int = 0, toIndex: Int = input.length): ByteArray
expect fun CharsetEncoder.encodeUTF8(input: ByteReadPacket, dst: Output): Unit
fun CharsetEncoder.encodeUTF8(input: ByteReadPacket): ByteReadPacket
package io.ktor.utils.io.concurrent
package io.ktor.utils.io.core
Module Contents
abstract class AbstractInput : Input
Module Contents
AbstractInput(head: IoBuffer = IoBuffer.Empty, remaining: Long = head.remainingAll(), pool: ObjectPool<ChunkBuffer> = ChunkBuffer.Pool)
AbstractInput(head: ChunkBuffer = ChunkBuffer.Empty, remaining: Long = head.remainingAll(), pool: ObjectPool<ChunkBuffer> = ChunkBuffer.Pool)
var byteOrder: ByteOrder
fun canRead(): Boolean
fun close(): Unit
protected abstract fun closeSource(): Unit
fun discard(n: Int): Int
fun discard(n: Long): Long
fun discardExact(n: Int): Unit
val endOfInput: Boolean
fun ensureNextHead(current: ChunkBuffer): ChunkBuffer?
protected abstract fun fill(destination: Memory, offset: Int, length: Int): Int
protected open fun fill(): ChunkBuffer?
fun fixGapAfterRead(current: ChunkBuffer): Unit
fun hasBytes(n: Int): Boolean
val isEmpty: Boolean
val isNotEmpty: Boolean
protected fun markNoMoreChunksAvailable(): Unit
fun peekTo(destination: Memory, destinationOffset: Long, offset: Long, min: Long, max: Long): Long
fun peekTo(buffer: IoBuffer): Int
val pool: ObjectPool<ChunkBuffer>
fun prepareReadHead(minSize: Int): ChunkBuffer?
fun readByte(): Byte
fun readDouble(): Double
fun readFloat(): Float
fun readFully(dst: ByteArray, offset: Int, length: Int): Unit
fun readInt(): Int
fun readLong(): Long
fun readShort(): Short
fun readText(out: Appendable, min: Int = 0, max: Int = Int.MAX_VALUE): Int
fun readText(min: Int = 0, max: Int = Int.MAX_VALUE): String
fun readTextExact(out: Appendable, exactCharacters: Int): Unit
fun readTextExact(exactCharacters: Int): String
fun release(): Unit
val remaining: Long
fun tryPeek(): Int
fun updateHeadRemaining(remaining: Int): Unit
abstract class AbstractOutput : Appendable, Output
open class Buffer
class BufferLimitExceededException : Exception
enum expect class ByteOrder
expect fun BytePacketBuilder(: Int = 0): BytePacketBuilder
class BytePacketBuilder : BytePacketBuilderPlatformBase
abstract class BytePacketBuilderBase : AbstractOutput
abstract class BytePacketBuilderPlatformBase : BytePacketBuilderBase
class ByteReadPacket : ByteReadPacketPlatformBase, Input
expect fun ByteReadPacket(array: ByteArray, offset: Int = 0, length: Int = array.size, block: (ByteArray) -> Unit): ByteReadPacket
inline fun ByteReadPacket(array: ByteArray, offset: Int = 0, length: Int = array.size): ByteReadPacket
fun ByteReadPacket(bb: ByteBuffer, release: (ByteBuffer) -> Unit = {}): ByteReadPacket
abstract class ByteReadPacketBase : AbstractInput
abstract class ByteReadPacketPlatformBase : ByteReadPacketBase
expect interface Closeable
expect class EOFException : IOException
annotation class ExperimentalIoApi
expect interface Input : Closeable
Module Contents
abstract var byteOrder: ByteOrder
abstract fun close(): Unit
abstract fun discard(n: Long): Long
abstract val endOfInput: Boolean
abstract fun peekTo(destination: Memory, destinationOffset: Long, offset: Long = 0, min: Long = 1, max: Long = Long.MAX_VALUE): Long
open fun peekTo(buffer: IoBuffer): Int
open fun readAvailable(dst: ByteArray, offset: Int, length: Int): Int
open fun readAvailable(dst: ShortArray, offset: Int, length: Int): Int
open fun readAvailable(dst: IntArray, offset: Int, length: Int): Int
open fun readAvailable(dst: LongArray, offset: Int, length: Int): Int
open fun readAvailable(dst: FloatArray, offset: Int, length: Int): Int
open fun readAvailable(dst: DoubleArray, offset: Int, length: Int): Int
open fun readAvailable(dst: IoBuffer, length: Int): Int
open fun readAvailable(dst: ByteBuffer, length: Int = dst.remaining()): Int
abstract fun readByte(): Byte
open fun readDouble(): Double
open fun readFloat(): Float
open fun readFully(dst: ByteArray, offset: Int, length: Int): Unit
open fun readFully(dst: ShortArray, offset: Int, length: Int): Unit
open fun readFully(dst: IntArray, offset: Int, length: Int): Unit
open fun readFully(dst: LongArray, offset: Int, length: Int): Unit
open fun readFully(dst: FloatArray, offset: Int, length: Int): Unit
open fun readFully(dst: DoubleArray, offset: Int, length: Int): Unit
open fun readFully(dst: IoBuffer, length: Int): Unit
open fun readFully(dst: ByteBuffer, length: Int = dst.remaining()): Unit
open fun readInt(): Int
open fun readLong(): Long
open fun readShort(): Short
abstract fun tryPeek(): Int
class InsufficientSpaceException : Exception
expect class IoBuffer : Input, Output, ChunkBuffer
Module Contents
IoBuffer(memory: Memory, origin: ChunkBuffer?)
IoBuffer(external: ByteBuffer)
val Empty: IoBuffer
val EmptyPool: ObjectPool<IoBuffer>
val NoPool: ObjectPool<IoBuffer>
val Pool: ObjectPool<IoBuffer>
val ReservedSize: Int
fun append(csq: CharSequence?, start: Int, end: Int): Appendable
fun append(csq: CharSequence?): Appendable
fun append(csq: CharArray, start: Int, end: Int): Appendable
fun append(c: Char): Appendable
fun appendChars(csq: CharArray, start: Int, end: Int): Int
fun appendChars(csq: CharSequence, start: Int, end: Int): Int
var byteOrder: ByteOrder
fun canRead(): Boolean
fun canWrite(): Boolean
fun close(): Unit
fun duplicate(): IoBuffer
val endOfInput: Boolean
fun fill(n: Long, v: Byte): Unit
fun flush(): Unit
fun getNext(): IoBuffer?
fun isExclusivelyOwned(): Boolean
fun makeView(): IoBuffer
fun peekTo(destination: Memory, destinationOffset: Long, offset: Long, min: Long, max: Long): Long
fun peekTo(buffer: IoBuffer): Int
fun pushBack(n: Int): Unit
fun read(dst: ByteBuffer, size: Int): Unit
fun read(dst: ByteArray, offset: Int, length: Int): Unit
fun readAvailable(dst: ByteArray, offset: Int, length: Int): Int
fun readAvailable(dst: IoBuffer, length: Int): Int
fun readAvailable(dst: ShortArray, offset: Int, length: Int): Int
fun readAvailable(dst: IntArray, offset: Int, length: Int): Int
fun readAvailable(dst: LongArray, offset: Int, length: Int): Int
fun readAvailable(dst: FloatArray, offset: Int, length: Int): Int
fun readAvailable(dst: DoubleArray, offset: Int, length: Int): Int
fun readAvailable(dst: ByteBuffer, length: Int): Int
inline fun readDirect(block: (ByteBuffer) -> Unit): Int
fun readDouble(): Double
fun readFloat(): Float
fun readFully(dst: ByteArray, offset: Int, length: Int): Unit
fun readFully(dst: IoBuffer, length: Int): Unit
fun readFully(dst: ShortArray, offset: Int, length: Int): Unit
fun readFully(dst: IntArray, offset: Int, length: Int): Unit
fun readFully(dst: LongArray, offset: Int, length: Int): Unit
fun readFully(dst: DoubleArray, offset: Int, length: Int): Unit
fun readFully(dst: FloatArray, offset: Int, length: Int): Unit
fun readFully(dst: ByteBuffer, length: Int): Unit
fun readInt(): Int
fun readLong(): Long
fun readShort(): Short
fun readText(decoder: CharsetDecoder, out: Appendable, lastBuffer: Boolean, max: Int = Int.MAX_VALUE): Int
fun release(pool: ObjectPool<IoBuffer>): Unit
fun resetFromContentToWrite(child: ByteBuffer): Unit
fun setNext(newNext: IoBuffer?): Unit
fun toString(): String
fun tryPeek(): Int
fun write(src: ByteBuffer): Unit
fun write(src: ByteArray, offset: Int, length: Int): Unit
fun writeBuffer(src: IoBuffer, length: Int): Int
inline fun writeDirect(size: Int, block: (ByteBuffer) -> Unit): Int
fun writeDouble(v: Double): Unit
fun writeFloat(v: Float): Unit
fun writeFully(src: ByteArray, offset: Int, length: Int): Unit
fun writeFully(src: ShortArray, offset: Int, length: Int): Unit
fun writeFully(src: IntArray, offset: Int, length: Int): Unit
fun writeFully(src: LongArray, offset: Int, length: Int): Unit
fun writeFully(src: FloatArray, offset: Int, length: Int): Unit
fun writeFully(src: DoubleArray, offset: Int, length: Int): Unit
fun writeFully(src: IoBuffer, length: Int): Unit
fun writeFully(bb: ByteBuffer): Unit
fun writeInt(v: Int): Unit
fun writeLong(v: Long): Unit
fun writeShort(v: Short): Unit
expect interface Output : Appendable, Closeable
Module Contents
abstract fun append(csq: CharArray, start: Int, end: Int): Appendable
abstract var byteOrder: ByteOrder
abstract fun close(): Unit
open fun fill(n: Long, v: Byte): Unit
abstract fun flush(): Unit
abstract fun writeByte(v: Byte): Unit
open fun writeDouble(v: Double): Unit
open fun writeFloat(v: Float): Unit
open fun writeFully(src: ByteArray, offset: Int, length: Int): Unit
open fun writeFully(src: ShortArray, offset: Int, length: Int): Unit
open fun writeFully(src: IntArray, offset: Int, length: Int): Unit
open fun writeFully(src: LongArray, offset: Int, length: Int): Unit
open fun writeFully(src: FloatArray, offset: Int, length: Int): Unit
open fun writeFully(src: DoubleArray, offset: Int, length: Int): Unit
open fun writeFully(src: IoBuffer, length: Int): Unit
open fun writeFully(bb: ByteBuffer): Unit
open fun writeInt(v: Int): Unit
open fun writeLong(v: Long): Unit
open fun writeShort(v: Short): Unit
expect val PACKET_MAX_COPY_SIZE: Int
expect fun String(bytes: ByteArray, offset: Int = 0, length: Int = bytes.size, charset: Charset = Charsets.UTF_8): String
fun Buffer.append(c: Char): Buffer
fun Buffer.append(csq: CharSequence?): Buffer
fun Buffer.append(csq: CharSequence?, start: Int, end: Int): Buffer
fun Buffer.append(csq: CharArray, start: Int, end: Int): Buffer
fun Output.append(csq: CharSequence, start: Int = 0, end: Int = csq.length): Appendable
fun Output.append(csq: CharArray, start: Int = 0, end: Int = csq.size): Appendable
inline fun buildPacket(: Int = 0, block: BytePacketBuilder.() -> Unit): ByteReadPacket
var Buffer.byteOrder: ByteOrder
inline fun Buffer.canRead(): Boolean
inline fun Buffer.canWrite(): Boolean
fun Input.copyTo(output: Output): Long
fun Input.discard(): Long
fun Input.discardExact(n: Long): Unit
fun Input.discardExact(n: Int): Unit
fun Input.discardUntilDelimiter(delimiter: Byte): Long
fun Input.discardUntilDelimiters(delimiter1: Byte, delimiter2: Byte): Long
fun Buffer.fill(times: Int, value: Byte): Unit
fun Buffer.fill(times: Int, value: <ERROR CLASS>): Unit
fun Buffer.fill(n: Long, v: Byte): Unit
fun Output.fill(times: Long, value: Byte = 0): Unit
fun Buffer.flush(): Unit
inline fun Buffer.forEach(block: (Byte) -> Unit): Unit
inline fun Input.forEach(block: (Byte) -> Unit): Unit
inline val Input.isEmpty: Boolean
inline val ByteReadPacket.isEmpty: Boolean
val Input.isNotEmpty: Boolean
inline val ByteReadPacket.isNotEmpty: Boolean
kotlin.String
fun Buffer.makeView(): Buffer
fun ChunkBuffer.makeView(): ChunkBuffer
fun Input.peekCharUtf8(): Char
fun Input.peekTo(destination: IoBuffer, offset: Int = 0, min: Int = 1, max: Int = Int.MAX_VALUE): Int
fun Input.peekTo(destination: Buffer, offset: Int = 0, min: Int = 1, max: Int = Int.MAX_VALUE): Int
inline fun <R> BytePacketBuilder.preview(block: (tmp: ByteReadPacket) -> R): R
fun Buffer.pushBack(n: Int): Unit
inline fun Buffer.read(block: (memory: Memory, start: Int, endExclusive: Int) -> Int): Int
fun Buffer.readAvailable(destination: ByteArray, offset: Int = 0, length: Int = destination.size - offset): Int
inline fun IoBuffer.readAvailable(destination: ByteArray, offset: Int = 0, length: Int = destination.size - offset): Int
fun Buffer.readAvailable(destination: <ERROR CLASS>, offset: Int = 0, length: Int = destination.size - offset): Int
fun Buffer.readAvailable(destination: ShortArray, offset: Int = 0, length: Int = destination.size - offset): Int
fun Buffer.readAvailable(destination: IntArray, offset: Int = 0, length: Int = destination.size - offset): Int
fun Buffer.readAvailable(destination: LongArray, offset: Int = 0, length: Int = destination.size - offset): Int
fun Buffer.readAvailable(destination: FloatArray, offset: Int = 0, length: Int = destination.size - offset): Int
fun Buffer.readAvailable(destination: DoubleArray, offset: Int = 0, length: Int = destination.size - offset): Int
fun Buffer.readAvailable(dst: Buffer, length: Int = dst.writeRemaining): Int
fun Input.readAvailable(dst: IoBuffer, size: Int = dst.writeRemaining): Int
fun Input.readAvailable(dst: ByteArray, offset: Int = 0, length: Int = dst.size - offset): Int
fun Input.readAvailable(dst: ShortArray, offset: Int = 0, length: Int = dst.size - offset): Int
fun Input.readAvailable(dst: IntArray, offset: Int = 0, length: Int = dst.size - offset): Int
fun Input.readAvailable(dst: LongArray, offset: Int = 0, length: Int = dst.size - offset): Int
fun Input.readAvailable(dst: FloatArray, offset: Int = 0, length: Int = dst.size - offset): Int
fun Input.readAvailable(dst: DoubleArray, offset: Int = 0, length: Int = dst.size - offset): Int
fun Input.readAvailable(dst: Buffer, length: Int = dst.writeRemaining): Int
fun Input.readAvailable(destination: Memory, destinationOffset: Int, length: Int): Int
fun Input.readAvailable(destination: Memory, destinationOffset: Long, length: Long): Long
fun ByteReadPacket.readAvailable(dst: ByteBuffer): Int
fun Input.readAvailable(dst: ByteBuffer, length: Int = dst.remaining()): Int
fun Buffer.readAvailable(dst: ByteBuffer, length: Int = dst.remaining()): Int
fun Input.readAvailableLittleEndian(dst: <ERROR CLASS>, offset: Int = 0, length: Int = dst.size - offset): Int
fun Input.readAvailableLittleEndian(dst: ShortArray, offset: Int = 0, length: Int = dst.size - offset): Int
fun Input.readAvailableLittleEndian(dst: IntArray, offset: Int = 0, length: Int = dst.size - offset): Int
fun Input.readAvailableLittleEndian(dst: LongArray, offset: Int = 0, length: Int = dst.size - offset): Int
fun Input.readAvailableLittleEndian(dst: FloatArray, offset: Int = 0, length: Int = dst.size - offset): Int
fun Input.readAvailableLittleEndian(dst: DoubleArray, offset: Int = 0, length: Int = dst.size - offset): Int
fun Buffer.readAvailableLittleEndian(dst: <ERROR CLASS>, offset: Int = 0, length: Int = dst.size - offset): Int
fun Buffer.readAvailableLittleEndian(dst: ShortArray, offset: Int = 0, length: Int = dst.size - offset): Int
fun Buffer.readAvailableLittleEndian(dst: IntArray, offset: Int = 0, length: Int = dst.size - offset): Int
fun Buffer.readAvailableLittleEndian(dst: LongArray, offset: Int = 0, length: Int = dst.size - offset): Int
fun Buffer.readAvailableLittleEndian(dst: FloatArray, offset: Int = 0, length: Int = dst.size - offset): Int
fun Buffer.readAvailableLittleEndian(dst: DoubleArray, offset: Int = 0, length: Int = dst.size - offset): Int
@JvmName("readAvailable") fun Input.readAvailableOld(dst: ByteArray, offset: Int = 0, length: Int = dst.size - offset): Int
@JvmName("readAvailable") fun Input.readAvailableOld(dst: ShortArray, offset: Int = 0, length: Int = dst.size - offset): Int
@JvmName("readAvailable") fun Input.readAvailableOld(dst: IntArray, offset: Int = 0, length: Int = dst.size - offset): Int
@JvmName("readAvailable") fun Input.readAvailableOld(dst: LongArray, offset: Int = 0, length: Int = dst.size - offset): Int
@JvmName("readAvailable") fun Input.readAvailableOld(dst: FloatArray, offset: Int = 0, length: Int = dst.size - offset): Int
@JvmName("readAvailable") fun Input.readAvailableOld(dst: DoubleArray, offset: Int = 0, length: Int = dst.size - offset): Int
fun ByteReadPacket.readByteBuffer(n: Int = remaining.coerceAtMostMaxIntOrFail("Unable to make a ByteBuffer: packet is too big"), direct: Boolean = false): ByteBuffer
fun Buffer.readBytes(count: Int = readRemaining): ByteArray
fun ByteReadPacket.readBytes(n: Int = remaining.coerceAtMostMaxIntOrFail("Unable to convert to a ByteArray: packet is too big")): ByteArray
fun Input.readBytes(n: Int): ByteArray
fun Input.readBytes(): ByteArray
fun Input.readBytesOf(min: Int = 0, max: Int = Int.MAX_VALUE): ByteArray
inline fun ByteReadPacket.readDirect(size: Int, block: (ByteBuffer) -> Unit): Unit
inline fun AbstractInput.readDirect(size: Int, block: (ByteBuffer) -> Unit): Unit
inline fun ByteReadPacketBase.readDirect(size: Int, block: (ByteBuffer) -> Unit): Unit
inline fun Buffer.readDirect(block: (ByteBuffer) -> Unit): Int
fun Buffer.readDouble(): Double
inline fun IoBuffer.readDouble(): Double
fun Input.readDouble(byteOrder: ByteOrder): Double
fun Input.readDouble(): Double
fun Input.readDoubleFallback(): Double
fun Input.readDoubleLittleEndian(): Double
fun Buffer.readDoubleLittleEndian(): Double
fun Buffer.readFloat(): Float
inline fun IoBuffer.readFloat(): Float
fun Input.readFloat(byteOrder: ByteOrder): Float
fun Input.readFloat(): Float
fun Input.readFloatFallback(): Float
fun Input.readFloatLittleEndian(): Float
fun Buffer.readFloatLittleEndian(): Float
fun Buffer.readFully(dst: Array<Byte>, offset: Int = 0, length: Int = dst.size - offset): Unit
fun Buffer.readFully(destination: ByteArray, offset: Int = 0, length: Int = destination.size - offset): Unit
inline fun IoBuffer.readFully(destination: ByteArray, offset: Int = 0, length: Int = destination.size - offset): Unit
fun Buffer.readFully(destination: <ERROR CLASS>, offset: Int = 0, length: Int = destination.size - offset): Unit
fun Buffer.readFully(destination: ShortArray, offset: Int = 0, length: Int = destination.size - offset): Unit
fun Buffer.readFully(destination: IntArray, offset: Int = 0, length: Int = destination.size - offset): Unit
fun Buffer.readFully(destination: LongArray, offset: Int = 0, length: Int = destination.size - offset): Unit
fun Buffer.readFully(destination: FloatArray, offset: Int = 0, length: Int = destination.size - offset): Unit
fun Buffer.readFully(destination: DoubleArray, offset: Int = 0, length: Int = destination.size - offset): Unit
fun Buffer.readFully(dst: Buffer, length: Int = dst.writeRemaining): Int
fun Input.readFully(dst: IoBuffer, size: Int = dst.writeRemaining): Unit
fun Input.readFully(dst: ByteArray, offset: Int = 0, length: Int = dst.size - offset): Unit
fun Input.readFully(dst: ShortArray, offset: Int = 0, length: Int = dst.size - offset): Unit
fun Input.readFully(dst: IntArray, offset: Int = 0, length: Int = dst.size - offset): Unit
fun Input.readFully(dst: LongArray, offset: Int = 0, length: Int = dst.size - offset): Unit
fun Input.readFully(dst: FloatArray, offset: Int = 0, length: Int = dst.size - offset): Unit
fun Input.readFully(dst: DoubleArray, offset: Int = 0, length: Int = dst.size - offset): Unit
fun Input.readFully(dst: Buffer, length: Int = dst.writeRemaining): Unit
fun Input.readFully(destination: Memory, destinationOffset: Int, length: Int): Unit
fun Input.readFully(destination: Memory, destinationOffset: Long, length: Long): Unit
@ExperimentalUnsignedTypes inline fun Input.readFully(dst: <ERROR CLASS>, offset: Int = 0, length: Int = dst.size - offset): Unit
fun Buffer.readFully(destination: ByteBuffer): Unit
fun ByteReadPacket.readFully(dst: ByteBuffer): Int
fun Input.readFully(dst: ByteBuffer, length: Int = dst.remaining()): Unit
fun Buffer.readFully(dst: ByteBuffer, length: Int): Unit
fun Input.readFullyLittleEndian(dst: <ERROR CLASS>, offset: Int = 0, length: Int = dst.size - offset): Unit
fun Input.readFullyLittleEndian(dst: ShortArray, offset: Int = 0, length: Int = dst.size - offset): Unit
fun Input.readFullyLittleEndian(dst: IntArray, offset: Int = 0, length: Int = dst.size - offset): Unit
fun Input.readFullyLittleEndian(dst: LongArray, offset: Int = 0, length: Int = dst.size - offset): Unit
fun Input.readFullyLittleEndian(dst: FloatArray, offset: Int = 0, length: Int = dst.size - offset): Unit
fun Input.readFullyLittleEndian(dst: DoubleArray, offset: Int = 0, length: Int = dst.size - offset): Unit
fun Buffer.readFullyLittleEndian(dst: <ERROR CLASS>, offset: Int = 0, length: Int = dst.size - offset): Unit
fun Buffer.readFullyLittleEndian(dst: ShortArray, offset: Int = 0, length: Int = dst.size - offset): Unit
fun Buffer.readFullyLittleEndian(dst: IntArray, offset: Int = 0, length: Int = dst.size - offset): Unit
fun Buffer.readFullyLittleEndian(dst: LongArray, offset: Int = 0, length: Int = dst.size - offset): Unit
fun Buffer.readFullyLittleEndian(dst: FloatArray, offset: Int = 0, length: Int = dst.size - offset): Unit
fun Buffer.readFullyLittleEndian(dst: DoubleArray, offset: Int = 0, length: Int = dst.size - offset): Unit
@JvmName("readFully") fun Input.readFullyOld(dst: ByteArray, offset: Int = 0, length: Int = dst.size - offset): Unit
@JvmName("readFully") fun Input.readFullyOld(dst: ShortArray, offset: Int = 0, length: Int = dst.size - offset): Unit
@JvmName("readFully") fun Input.readFullyOld(dst: IntArray, offset: Int = 0, length: Int = dst.size - offset): Unit
@JvmName("readFully") fun Input.readFullyOld(dst: LongArray, offset: Int = 0, length: Int = dst.size - offset): Unit
@JvmName("readFully") fun Input.readFullyOld(dst: FloatArray, offset: Int = 0, length: Int = dst.size - offset): Unit
@JvmName("readFully") fun Input.readFullyOld(dst: DoubleArray, offset: Int = 0, length: Int = dst.size - offset): Unit
fun Buffer.readInt(): Int
inline fun IoBuffer.readInt(): Int
fun Input.readInt(byteOrder: ByteOrder): Int
fun Input.readInt(): Int
fun Input.readIntLittleEndian(): Int
fun Buffer.readIntLittleEndian(): Int
fun Buffer.readLong(): Long
inline fun IoBuffer.readLong(): Long
fun Input.readLong(byteOrder: ByteOrder): Long
fun Input.readLong(): Long
fun Input.readLongLittleEndian(): Long
fun Buffer.readLongLittleEndian(): Long
fun Buffer.readShort(): Short
inline fun IoBuffer.readShort(): Short
fun Input.readShort(byteOrder: ByteOrder): Short
fun Input.readShort(): Short
fun Input.readShortLittleEndian(): Short
fun Buffer.readShortLittleEndian(): Short
fun Buffer.readText(decoder: CharsetDecoder, out: Appendable, lastBuffer: Boolean, max: Int = Int.MAX_VALUE): Int
fun Input.readText(out: Appendable, decoder: CharsetDecoder, max: Int = Int.MAX_VALUE): Int
fun Input.readText(out: Appendable, charset: Charset = Charsets.UTF_8, max: Int = Int.MAX_VALUE): Int
fun Input.readText(decoder: CharsetDecoder, max: Int = Int.MAX_VALUE): String
fun Input.readText(charset: Charset = Charsets.UTF_8, max: Int = Int.MAX_VALUE): String
fun Buffer.readText(charset: Charset = Charsets.UTF_8, max: Int = Int.MAX_VALUE): String
fun ByteReadPacket.readText(decoder: CharsetDecoder, out: Appendable, max: Int = Int.MAX_VALUE): Int
fun Input.readTextExact(charset: Charset = Charsets.UTF_8, n: Int): String
fun Input.readTextExactBytes(charset: Charset = Charsets.UTF_8, bytes: Int): String
fun Input.readTextExactBytes(bytesCount: Int, charset: Charset = Charsets.UTF_8): String
fun Input.readTextExactCharacters(charactersCount: Int, charset: Charset = Charsets.UTF_8): String
fun Buffer.readUByte(): <ERROR CLASS>
inline fun IoBuffer.readUByte(): <ERROR CLASS>
@ExperimentalUnsignedTypes inline fun Input.readUByte(): <ERROR CLASS>
fun Buffer.readUInt(): <ERROR CLASS>
inline fun IoBuffer.readUInt(): <ERROR CLASS>
@ExperimentalUnsignedTypes inline fun Input.readUInt(): <ERROR CLASS>
fun Buffer.readULong(): <ERROR CLASS>
inline fun IoBuffer.readULong(): <ERROR CLASS>
@ExperimentalUnsignedTypes inline fun Input.readULong(): <ERROR CLASS>
fun Buffer.readUShort(): <ERROR CLASS>
inline fun IoBuffer.readUShort(): <ERROR CLASS>
@ExperimentalUnsignedTypes inline fun Input.readUShort(): <ERROR CLASS>
fun ByteReadPacket.readUTF8Line(estimate: Int = 16, limit: Int = Int.MAX_VALUE): String?
fun Input.readUTF8Line(estimate: Int = 16, limit: Int = Int.MAX_VALUE): String?
fun Input.readUTF8LineTo(out: Appendable, limit: Int): Boolean
fun Input.readUTF8UntilDelimiter(delimiters: String, limit: Int = Int.MAX_VALUE): String
fun Input.readUTF8UntilDelimiterTo(out: Appendable, delimiters: String, limit: Int = Int.MAX_VALUE): Int
fun Input.readUTF8UntilDelimiterTo(out: Output, delimiters: String, limit: Int = Int.MAX_VALUE): Int
fun Input.readUTF8UntilDelimiterTo(out: BytePacketBuilderBase, delimiters: String, limit: Int = Int.MAX_VALUE): Int
fun Input.readUntilDelimiter(delimiter: Byte, dst: ByteArray, offset: Int = 0, length: Int = dst.size): Int
fun Input.readUntilDelimiter(delimiter: Byte, dst: Output): Long
fun Input.readUntilDelimiters(delimiter1: Byte, delimiter2: Byte, dst: ByteArray, offset: Int = 0, length: Int = dst.size): Int
fun Input.readUntilDelimiters(delimiter1: Byte, delimiter2: Byte, dst: Output): Long
fun IoBuffer.release(pool: ObjectPool<IoBuffer>): Unit
fun ChunkBuffer.remainingAll(): Long
fun remainingAll(buffer: IoBuffer): Long
fun BytePacketBuilder.reset(): Unit
inline fun Input.takeWhile(block: (Buffer) -> Boolean): Unit
inline fun Input.takeWhileSize(initialSize: Int = 1, block: (Buffer) -> Int): Unit
fun Buffer.tryPeek(): Int
inline fun <C, R> C.use(block: (C) -> R): R
inline fun <I : Input, R> I.use(block: (I) -> R): R
inline fun <O : Output, R> O.use(block: (O) -> R): R
inline fun <R> withBuffer(size: Int, block: Buffer.() -> R): R
inline fun <R> withBuffer(pool: ObjectPool<Buffer>, block: Buffer.() -> R): R
inline fun Buffer.write(block: (memory: Memory, start: Int, endExclusive: Int) -> Int): Int
inline fun BytePacketBuilder.writeByteBufferDirect(size: Int, block: (ByteBuffer) -> Unit): Int
inline fun BytePacketBuilder.writeDirect(size: Int, block: (ByteBuffer) -> Unit): Unit
inline fun Buffer.writeDirect(size: Int = 1, block: (ByteBuffer) -> Unit): Int
fun Buffer.writeDouble(value: Double): Unit
inline fun IoBuffer.writeDouble(value: Double): Unit
fun Output.writeDouble(value: Double, byteOrder: ByteOrder): Unit
fun Output.writeDouble(value: Double): Unit
fun Output.writeDoubleLittleEndian(value: Double): Unit
fun Buffer.writeDoubleLittleEndian(value: Double): Unit
fun Buffer.writeFloat(value: Float): Unit
inline fun IoBuffer.writeFloat(value: Float): Unit
fun Output.writeFloat(value: Float, byteOrder: ByteOrder): Unit
fun Output.writeFloat(value: Float): Unit
fun Output.writeFloatLittleEndian(value: Float): Unit
fun Buffer.writeFloatLittleEndian(value: Float): Unit
fun Buffer.writeFully(source: ByteArray, offset: Int = 0, length: Int = source.size - offset): Unit
inline fun IoBuffer.writeFully(source: ByteArray, offset: Int = 0, length: Int = source.size - offset): Unit
fun Buffer.writeFully(source: <ERROR CLASS>, offset: Int = 0, length: Int = source.size - offset): Unit
fun Buffer.writeFully(source: ShortArray, offset: Int = 0, length: Int = source.size - offset): Unit
fun Buffer.writeFully(source: IntArray, offset: Int = 0, length: Int = source.size - offset): Unit
fun Buffer.writeFully(source: LongArray, offset: Int = 0, length: Int = source.size - offset): Unit
fun Buffer.writeFully(source: FloatArray, offset: Int = 0, length: Int = source.size - offset): Unit
fun Buffer.writeFully(source: DoubleArray, offset: Int = 0, length: Int = source.size - offset): Unit
fun Buffer.writeFully(src: Buffer): Unit
fun Buffer.writeFully(src: Buffer, length: Int): Unit
fun Output.writeFully(src: ByteArray, offset: Int = 0, length: Int = src.size - offset): Unit
fun Output.writeFully(src: ShortArray, offset: Int = 0, length: Int = src.size - offset): Unit
fun Output.writeFully(src: IntArray, offset: Int = 0, length: Int = src.size - offset): Unit
fun Output.writeFully(src: LongArray, offset: Int = 0, length: Int = src.size - offset): Unit
fun Output.writeFully(src: FloatArray, offset: Int = 0, length: Int = src.size - offset): Unit
fun Output.writeFully(src: DoubleArray, offset: Int = 0, length: Int = src.size - offset): Unit
fun Output.writeFully(src: IoBuffer, length: Int = src.readRemaining): Unit
fun Output.writeFully(src: Buffer, length: Int = src.readRemaining): Unit
fun Output.writeFully(src: Memory, offset: Int, length: Int): Unit
fun Output.writeFully(src: Memory, offset: Long, length: Long): Unit
@ExperimentalUnsignedTypes inline fun Output.writeFully(array: <ERROR CLASS>, offset: Int = 0, length: Int = array.size - offset): Unit
fun Buffer.writeFully(source: ByteBuffer): Unit
fun BytePacketBuilder.writeFully(src: ByteBuffer): Unit
fun Output.writeFully(bb: ByteBuffer): Unit
fun Output.writeFullyLittleEndian(source: <ERROR CLASS>, offset: Int = 0, length: Int = source.size - offset): Unit
fun Buffer.writeFullyLittleEndian(source: <ERROR CLASS>, offset: Int = 0, length: Int = source.size - offset): Unit
fun Output.writeFullyLittleEndian(source: ShortArray, offset: Int = 0, length: Int = source.size - offset): Unit
fun Output.writeFullyLittleEndian(source: IntArray, offset: Int = 0, length: Int = source.size - offset): Unit
fun Output.writeFullyLittleEndian(source: LongArray, offset: Int = 0, length: Int = source.size - offset): Unit
fun Output.writeFullyLittleEndian(source: FloatArray, offset: Int = 0, length: Int = source.size - offset): Unit
fun Output.writeFullyLittleEndian(source: DoubleArray, offset: Int = 0, length: Int = source.size - offset): Unit
fun Buffer.writeFullyLittleEndian(source: ShortArray, offset: Int = 0, length: Int = source.size - offset): Unit
fun Buffer.writeFullyLittleEndian(source: IntArray, offset: Int = 0, length: Int = source.size - offset): Unit
fun Buffer.writeFullyLittleEndian(source: LongArray, offset: Int = 0, length: Int = source.size - offset): Unit
fun Buffer.writeFullyLittleEndian(source: FloatArray, offset: Int = 0, length: Int = source.size - offset): Unit
fun Buffer.writeFullyLittleEndian(source: DoubleArray, offset: Int = 0, length: Int = source.size - offset): Unit
fun Buffer.writeInt(value: Int): Unit
inline fun IoBuffer.writeInt(value: Int): Unit
fun Output.writeInt(value: Int, byteOrder: ByteOrder): Unit
fun Output.writeInt(value: Int): Unit
fun Output.writeIntLittleEndian(value: Int): Unit
fun Buffer.writeIntLittleEndian(value: Int): Unit
fun Buffer.writeLong(value: Long): Unit
inline fun IoBuffer.writeLong(value: Long): Unit
fun Output.writeLong(value: Long, byteOrder: ByteOrder): Unit
fun Output.writeLong(value: Long): Unit
fun Output.writeLongLittleEndian(value: Long): Unit
fun Buffer.writeLongLittleEndian(value: Long): Unit
fun Output.writePacket(packet: ByteReadPacket): Unit
fun Buffer.writeShort(value: Short): Unit
inline fun IoBuffer.writeShort(value: Short): Unit
fun Output.writeShort(value: Short, byteOrder: ByteOrder): Unit
fun Output.writeShort(value: Short): Unit
fun Output.writeShortLittleEndian(value: Short): Unit
fun Buffer.writeShortLittleEndian(value: Short): Unit
fun Output.writeText(text: CharSequence, fromIndex: Int = 0, toIndex: Int = text.length, encoder: CharsetEncoder): Unit
fun Output.writeText(text: CharSequence, fromIndex: Int = 0, toIndex: Int = text.length, charset: Charset = Charsets.UTF_8): Unit
fun Output.writeText(text: CharArray, fromIndex: Int = 0, toIndex: Int = text.size, charset: Charset = Charsets.UTF_8): Unit
fun Buffer.writeUByte(value: <ERROR CLASS>): Unit
fun IoBuffer.writeUByte(value: <ERROR CLASS>): Unit
@ExperimentalUnsignedTypes inline fun Output.writeUByte(v: <ERROR CLASS>): Unit
fun Buffer.writeUInt(value: <ERROR CLASS>): Unit
inline fun IoBuffer.writeUInt(value: <ERROR CLASS>): Unit
@ExperimentalUnsignedTypes inline fun Output.writeUInt(v: <ERROR CLASS>): Unit
fun Buffer.writeULong(value: <ERROR CLASS>): Unit
inline fun IoBuffer.writeULong(value: <ERROR CLASS>): Unit
@ExperimentalUnsignedTypes inline fun Output.writeULong(v: <ERROR CLASS>): Unit
fun Buffer.writeUShort(value: <ERROR CLASS>): Unit
inline fun IoBuffer.writeUShort(value: <ERROR CLASS>): Unit
@ExperimentalUnsignedTypes inline fun Output.writeUShort(v: <ERROR CLASS>): Unit
inline fun Output.writeWhile(block: (Buffer) -> Boolean): Unit
inline fun Output.writeWhileSize(initialSize: Int = 1, block: (Buffer) -> Int): Unit
package io.ktor.utils.io.core.internal
package io.ktor.utils.io.errors
package io.ktor.utils.io.jvm.javaio
package io.ktor.utils.io.jvm.nio
package io.ktor.utils.io.nio
package io.ktor.utils.io.pool
package io.ktor.utils.io.streams