Object/Class

zio.stream

ZPipeline

Related Docs: class ZPipeline | package stream

Permalink

object ZPipeline extends ZPipelinePlatformSpecificConstructors

Linear Supertypes
ZPipelinePlatformSpecificConstructors, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. ZPipeline
  2. ZPipelinePlatformSpecificConstructors
  3. AnyRef
  4. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Type Members

  1. final class EnvironmentWithPipelinePartiallyApplied[Env] extends AnyVal

    Permalink
  2. final class ServiceWithPipelinePartiallyApplied[Service] extends AnyVal

    Permalink
  3. final class UnwrapScopedPartiallyApplied[Env] extends AnyVal

    Permalink

Value Members

  1. final def !=(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  2. final def ##(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  3. final def ==(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  4. def append[In](values: ⇒ Chunk[In])(implicit trace: Trace): ZPipeline[Any, Nothing, In, In]

    Permalink
  5. def apply[In](implicit trace: Trace): ZPipeline[Any, Nothing, In, In]

    Permalink

    A shorter version of ZPipeline.identity, which can facilitate more compact definition of pipelines.

    A shorter version of ZPipeline.identity, which can facilitate more compact definition of pipelines.

    ZPipeline[Int] >>> ZPipeline.filter(_ % 2 != 0)
  6. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  7. def branchAfter[Env, Err, In, Out](n: ⇒ Int)(f: (Chunk[In]) ⇒ ZPipeline[Env, Err, In, Out])(implicit trace: Trace): ZPipeline[Env, Err, In, Out]

    Permalink

    A dynamic pipeline that first collects n elements from the stream, then creates another pipeline with the function f and sends all the following elements through that.

  8. def changes[Err, In](implicit trace: Trace): ZPipeline[Any, Err, In, In]

    Permalink
  9. def changesWith[Err, In](f: (In, In) ⇒ Boolean)(implicit trace: Trace): ZPipeline[Any, Err, In, In]

    Permalink
  10. def changesWithZIO[Env, Err, In](f: (In, In) ⇒ ZIO[Env, Err, Boolean])(implicit trace: Trace): ZPipeline[Env, Err, In, In]

    Permalink
  11. def chunks[In](implicit trace: Trace): ZPipeline[Any, Nothing, In, Chunk[In]]

    Permalink

    Creates a pipeline that exposes the chunk structure of the stream.

  12. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  13. def collect[In, Out](f: PartialFunction[In, Out])(implicit trace: Trace): ZPipeline[Any, Nothing, In, Out]

    Permalink

    Creates a pipeline that collects elements with the specified partial function.

    Creates a pipeline that collects elements with the specified partial function.

    ZPipeline.collect[Option[Int], Int] { case Some(v) => v }
  14. def collectLeft[Err, A, B](implicit trace: Trace): ZPipeline[Any, Err, Either[A, B], A]

    Permalink
  15. def collectRight[Err, A, B](implicit trace: Trace): ZPipeline[Any, Err, Either[A, B], B]

    Permalink
  16. def collectSome[Err, A](implicit trace: Trace): ZPipeline[Any, Err, Option[A], A]

    Permalink
  17. def collectSuccess[A, B](implicit trace: Trace): ZPipeline[Any, Nothing, Exit[B, A], A]

    Permalink
  18. def collectWhile[Err, In, Out](pf: PartialFunction[In, Out])(implicit trace: Trace): ZPipeline[Any, Err, In, Out]

    Permalink
  19. def collectWhileLeft[Err, A, B](implicit trace: Trace): ZPipeline[Any, Err, Either[A, B], A]

    Permalink
  20. def collectWhileRight[Err, A, B](implicit trace: Trace): ZPipeline[Any, Err, Either[A, B], B]

    Permalink
  21. def collectWhileSome[Err, A](implicit trace: Trace): ZPipeline[Any, Err, Option[A], A]

    Permalink
  22. def collectWhileSuccess[Err, A](implicit trace: Trace): ZPipeline[Any, Nothing, Exit[Err, A], A]

    Permalink
  23. def collectWhileZIO[Env, Err, In, Out](pf: PartialFunction[In, ZIO[Env, Err, Out]])(implicit trace: Trace): ZPipeline[Env, Err, In, Out]

    Permalink
  24. def decodeCharsWith(charset: ⇒ Charset, bufSize: ⇒ Int = 4096)(implicit trace: Trace): ZPipeline[Any, CharacterCodingException, Byte, Char]

    Permalink

    Creates a pipeline that decodes a stream of bytes into a stream of characters using the given charset

  25. def decodeStringWith(charset: ⇒ Charset)(implicit trace: Trace): ZPipeline[Any, CharacterCodingException, Byte, String]

    Permalink

    Creates a pipeline that decodes a stream of bytes into a stream of strings using the given charset

  26. def drain[Err](implicit trace: Trace): ZPipeline[Any, Err, Any, Nothing]

    Permalink
  27. def drop[In](n: ⇒ Int)(implicit trace: Trace): ZPipeline[Any, Nothing, In, In]

    Permalink

    Creates a pipeline that drops n elements.

  28. def dropRight[Err, In](n: ⇒ Int)(implicit trace: Trace): ZPipeline[Any, Err, In, In]

    Permalink
  29. def dropUntil[In](f: (In) ⇒ Boolean)(implicit trace: Trace): ZPipeline[Any, Nothing, In, In]

    Permalink

    Creates a pipeline that drops elements until the specified predicate evaluates to true.

    Creates a pipeline that drops elements until the specified predicate evaluates to true.

    ZPipeline.dropUntil[Int](_ > 100)
  30. def dropUntilZIO[Env, Err, In](p: (In) ⇒ ZIO[Env, Err, Boolean])(implicit trace: Trace): ZPipeline[Env, Err, In, In]

    Permalink

    Drops incoming elements until the effectful predicate p is satisfied.

  31. def dropWhile[In](f: (In) ⇒ Boolean)(implicit trace: Trace): ZPipeline[Any, Nothing, In, In]

    Permalink

    Creates a pipeline that drops elements while the specified predicate evaluates to true.

    Creates a pipeline that drops elements while the specified predicate evaluates to true.

    ZPipeline.dropWhile[Int](_ <= 100)
  32. def dropWhileZIO[Env, Err, In, Out](p: (In) ⇒ ZIO[Env, Err, Boolean])(implicit trace: Trace): ZPipeline[Env, Err, In, In]

    Permalink

    Drops incoming elements as long as the effectful predicate p is satisfied.

  33. def encodeCharsWith(charset: ⇒ Charset, bufferSize: ⇒ Int = 4096)(implicit trace: Trace): ZPipeline[Any, CharacterCodingException, Char, Byte]

    Permalink

    Creates a pipeline that converts a stream of characters into a stream of bytes using the given charset

  34. def encodeStringWith(charset: ⇒ Charset, bom: ⇒ Chunk[Byte] = Chunk.empty)(implicit trace: Trace): ZPipeline[Any, CharacterCodingException, String, Byte]

    Permalink

    Creates a pipeline that converts a stream of strings into a stream of bytes using the given charset

  35. def environmentWithPipeline[Env]: EnvironmentWithPipelinePartiallyApplied[Env]

    Permalink

    Accesses the environment of the pipeline in the context of a pipeline.

  36. final def eq(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  37. def equals(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  38. def filter[In](f: (In) ⇒ Boolean)(implicit trace: Trace): ZPipeline[Any, Nothing, In, In]

    Permalink

    Creates a pipeline that filters elements according to the specified predicate.

  39. def filterZIO[Env, Err, In](f: (In) ⇒ ZIO[Env, Err, Boolean])(implicit trace: Trace): ZPipeline[Env, Err, In, In]

    Permalink
  40. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  41. def flattenChunks[In](implicit trace: Trace): ZPipeline[Any, Nothing, Chunk[In], In]

    Permalink

    Creates a pipeline that submerges chunks into the structure of the stream.

  42. def flattenExit[Err, Out](implicit trace: Trace): ZPipeline[Any, Err, Exit[Err, Out], Out]

    Permalink

    Creates a pipeline that converts exit results into a stream of values with failure terminating the stream.

  43. def flattenIterables[Out](implicit trace: Trace): ZPipeline[Any, Nothing, Iterable[Out], Out]

    Permalink

    Creates a pipeline that submerges iterables into the structure of the stream.

  44. def flattenStreamsPar[Env, Err, Out](n: ⇒ Int, outputBuffer: ⇒ Int = 16)(implicit trace: Trace): ZPipeline[Env, Err, ZStream[Env, Err, Out], Out]

    Permalink

    Creates a pipeline that flattens a stream of streams into a single stream of values.

    Creates a pipeline that flattens a stream of streams into a single stream of values. The streams are merged in parallel up to the specified maximum concurrency and will buffer up to output buffer size elements.

  45. def fromChannel[Env, Err, In, Out](channel: ⇒ ZChannel[Env, Nothing, Chunk[In], Any, Err, Chunk[Out], Any]): ZPipeline[Env, Err, In, Out]

    Permalink

    Creates a pipeline that sends all the elements through the given channel.

  46. def fromPush[Env, Err, In, Out](push: ⇒ ZIO[Scope with Env, Nothing, (Option[Chunk[In]]) ⇒ ZIO[Env, Err, Chunk[Out]]])(implicit trace: Trace): ZPipeline[Env, Err, In, Out]

    Permalink

    Creates a pipeline from a chunk processing function.

  47. def fromSink[Env, Err, In, Out](sink: ⇒ ZSink[Env, Err, In, In, Out])(implicit trace: Trace): ZPipeline[Env, Err, In, Out]

    Permalink

    Creates a pipeline that repeatedly sends all elements through the given sink.

  48. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  49. def groupAdjacentBy[In, Key](f: (In) ⇒ Key)(implicit trace: Trace): ZPipeline[Any, Nothing, In, (Key, NonEmptyChunk[In])]

    Permalink

    Creates a pipeline that groups on adjacent keys, calculated by function f.

  50. def grouped[In](chunkSize: ⇒ Int)(implicit trace: Trace): ZPipeline[Any, Nothing, In, Chunk[In]]

    Permalink
  51. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  52. def identity[In](implicit trace: Trace): ZPipeline[Any, Nothing, In, In]

    Permalink

    The identity pipeline, which does not modify streams in any way.

  53. def intersperse[In](start: ⇒ In, middle: ⇒ In, end: ⇒ In)(implicit trace: Trace): ZPipeline[Any, Nothing, In, In]

    Permalink
  54. def intersperse[Err, In](middle: ⇒ In)(implicit trace: Trace): ZPipeline[Any, Err, In, In]

    Permalink
  55. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  56. def iso_8859_1Decode(implicit trace: Trace): ZPipeline[Any, CharacterCodingException, Byte, String]

    Permalink

    Creates a pipeline that converts a stream of bytes into a stream of strings using the ISO_8859_1 charset

  57. def iso_8859_1Encode(implicit trace: Trace): ZPipeline[Any, CharacterCodingException, String, Byte]

    Permalink

    Creates a pipeline that converts a stream of strings into a stream of bytes using the ISO_8859_1 charset

  58. def map[In, Out](f: (In) ⇒ Out)(implicit trace: Trace): ZPipeline[Any, Nothing, In, Out]

    Permalink

    Creates a pipeline that maps elements with the specified function.

  59. def mapAccum[In, State, Out](s: ⇒ State)(f: (State, In) ⇒ (State, Out))(implicit trace: Trace): ZPipeline[Any, Nothing, In, Out]

    Permalink

    Creates a pipeline that statefully maps elements with the specified function.

  60. def mapAccumZIO[Env, Err, In, State, Out](s: ⇒ State)(f: (State, In) ⇒ ZIO[Env, Err, (State, Out)])(implicit trace: Trace): ZPipeline[Env, Err, In, Out]

    Permalink

    Creates a pipeline that statefully maps elements with the specified effect.

  61. def mapChunks[In, Out](f: (Chunk[In]) ⇒ Chunk[Out])(implicit trace: Trace): ZPipeline[Any, Nothing, In, Out]

    Permalink

    Creates a pipeline that maps chunks of elements with the specified function.

  62. def mapChunksZIO[Env, Err, In, Out](f: (Chunk[In]) ⇒ ZIO[Env, Err, Chunk[Out]])(implicit trace: Trace): ZPipeline[Env, Err, In, Out]

    Permalink

    Creates a pipeline that maps chunks of elements with the specified effect.

  63. def mapStream[Env, Err, In, Out](f: (In) ⇒ ZStream[Env, Err, Out])(implicit trace: Trace): ZPipeline[Env, Err, In, Out]

    Permalink

    Creates a pipeline that maps elements with the specified function that returns a stream.

  64. def mapZIO[Env, Err, In, Out](f: (In) ⇒ ZIO[Env, Err, Out])(implicit trace: Trace): ZPipeline[Env, Err, In, Out]

    Permalink

    Creates a pipeline that maps elements with the specified effectful function.

  65. final def ne(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  66. final def notify(): Unit

    Permalink
    Definition Classes
    AnyRef
  67. final def notifyAll(): Unit

    Permalink
    Definition Classes
    AnyRef
  68. def prepend[In](values: ⇒ Chunk[In])(implicit trace: Trace): ZPipeline[Any, Nothing, In, In]

    Permalink

    Emits the provided chunk before emitting any other value.

  69. def rechunk[In](n: ⇒ Int)(implicit trace: Trace): ZPipeline[Any, Nothing, In, In]

    Permalink

    A pipeline that rechunks the stream into chunks of the specified size.

  70. def scan[In, Out](s: ⇒ Out)(f: (Out, In) ⇒ Out)(implicit trace: Trace): ZPipeline[Any, Nothing, In, Out]

    Permalink

    Creates a pipeline that scans elements with the specified function.

  71. def scanZIO[Env, Err, In, Out](s: ⇒ Out)(f: (Out, In) ⇒ ZIO[Env, Err, Out])(implicit trace: Trace): ZPipeline[Env, Err, In, Out]

    Permalink

    Creates a pipeline that scans elements with the specified function.

  72. def serviceWithPipeline[Service]: ServiceWithPipelinePartiallyApplied[Service]

    Permalink

    Accesses the specified service in the environment of the pipeline in the context of a pipeline.

  73. def splitLines(implicit trace: Trace): ZPipeline[Any, Nothing, String, String]

    Permalink

    Splits strings on newlines.

    Splits strings on newlines. Handles both Windows newlines (\r\n) and UNIX newlines (\n).

  74. def splitOn(delimiter: ⇒ String)(implicit trace: Trace): ZPipeline[Any, Nothing, String, String]

    Permalink

    Splits strings on a delimiter.

  75. def splitOnChunk[In](delimiter: ⇒ Chunk[In])(implicit trace: Trace): ZPipeline[Any, Nothing, In, In]

    Permalink

    Splits strings on a delimiter.

  76. def suspend[Env, Err, In, Out](pipeline: ⇒ ZPipeline[Env, Err, In, Out]): ZPipeline[Env, Err, In, Out]

    Permalink

    Lazily constructs a pipeline.

  77. final def synchronized[T0](arg0: ⇒ T0): T0

    Permalink
    Definition Classes
    AnyRef
  78. def take[In](n: ⇒ Long)(implicit trace: Trace): ZPipeline[Any, Nothing, In, In]

    Permalink

    Creates a pipeline that takes n elements.

  79. def takeUntil[In](f: (In) ⇒ Boolean)(implicit trace: Trace): ZPipeline[Any, Nothing, In, In]

    Permalink

    Creates a pipeline that takes elements until the specified predicate evaluates to true.

  80. def takeWhile[In](f: (In) ⇒ Boolean)(implicit trace: Trace): ZPipeline[Any, Nothing, In, In]

    Permalink

    Creates a pipeline that takes elements while the specified predicate evaluates to true.

  81. def tap[Env, Err, In](f: (In) ⇒ ZIO[Env, Err, Any])(implicit trace: Trace): ZPipeline[Env, Err, In, In]

    Permalink

    Adds an effect to consumption of every element of the pipeline.

  82. def throttleEnforce[In](units: Long, duration: ⇒ zio.Duration, burst: ⇒ Long = 0)(costFn: (Chunk[In]) ⇒ Long)(implicit trace: Trace): ZPipeline[Any, Nothing, In, In]

    Permalink

    Throttles the chunks of this pipeline according to the given bandwidth parameters using the token bucket algorithm.

    Throttles the chunks of this pipeline according to the given bandwidth parameters using the token bucket algorithm. Allows for burst in the processing of elements by allowing the token bucket to accumulate tokens up to a units + burst threshold. Chunks that do not meet the bandwidth constraints are dropped. The weight of each chunk is determined by the costFn function.

  83. def throttleEnforceZIO[Env, Err, In](units: ⇒ Long, duration: ⇒ zio.Duration, burst: ⇒ Long = 0)(costFn: (Chunk[In]) ⇒ ZIO[Env, Err, Long])(implicit trace: Trace): ZPipeline[Env, Err, In, In]

    Permalink

    Throttles the chunks of this pipeline according to the given bandwidth parameters using the token bucket algorithm.

    Throttles the chunks of this pipeline according to the given bandwidth parameters using the token bucket algorithm. Allows for burst in the processing of elements by allowing the token bucket to accumulate tokens up to a units + burst threshold. Chunks that do not meet the bandwidth constraints are dropped. The weight of each chunk is determined by the costFn effectful function.

  84. def throttleShape[In](units: ⇒ Long, duration: ⇒ zio.Duration, burst: Long = 0)(costFn: (Chunk[In]) ⇒ Long)(implicit trace: Trace): ZPipeline[Any, Nothing, In, In]

    Permalink

    Delays the chunks of this pipeline according to the given bandwidth parameters using the token bucket algorithm.

    Delays the chunks of this pipeline according to the given bandwidth parameters using the token bucket algorithm. Allows for burst in the processing of elements by allowing the token bucket to accumulate tokens up to a units + burst threshold. The weight of each chunk is determined by the costFn function.

  85. def throttleShapeZIO[Env, Err, In](units: ⇒ Long, duration: ⇒ zio.Duration, burst: ⇒ Long = 0)(costFn: (Chunk[In]) ⇒ ZIO[Env, Err, Long])(implicit trace: Trace): ZPipeline[Env, Err, In, In]

    Permalink

    Delays the chunks of this pipeline according to the given bandwidth parameters using the token bucket algorithm.

    Delays the chunks of this pipeline according to the given bandwidth parameters using the token bucket algorithm. Allows for burst in the processing of elements by allowing the token bucket to accumulate tokens up to a units + burst threshold. The weight of each chunk is determined by the costFn effectful function.

  86. def toString(): String

    Permalink
    Definition Classes
    AnyRef → Any
  87. def unwrap[Env, Err, In, Out](zio: ZIO[Env, Err, ZPipeline[Env, Err, In, Out]])(implicit trace: Trace): ZPipeline[Env, Err, In, Out]

    Permalink

    Creates a pipeline produced from an effect.

  88. def unwrapScoped[Env]: UnwrapScopedPartiallyApplied[Env]

    Permalink

    Created a pipeline produced from a scoped effect.

  89. def usASCIIDecode(implicit trace: Trace): ZPipeline[Any, CharacterCodingException, Byte, String]

    Permalink

    Creates a pipeline that converts a stream of bytes into a stream of strings using the US ASCII charset

  90. def usASCIIEncode(implicit trace: Trace): ZPipeline[Any, CharacterCodingException, String, Byte]

    Permalink

    Creates a pipeline that converts a stream of strings into a stream of bytes using the US ASCII charset

  91. def utf16BEDecode(implicit trace: Trace): ZPipeline[Any, CharacterCodingException, Byte, String]

    Permalink

    Creates a pipeline that converts a stream of bytes into a stream of strings using the UTF_16BE charset

  92. def utf16BEEncode(implicit trace: Trace): ZPipeline[Any, CharacterCodingException, String, Byte]

    Permalink

    Creates a pipeline that converts a stream of strings into a stream of bytes using the UTF_16BE charset, without adding a BOM

  93. def utf16BEWithBomEncode(implicit trace: Trace): ZPipeline[Any, CharacterCodingException, String, Byte]

    Permalink

    Creates a pipeline that converts a stream of strings into a stream of bytes using the UTF_16BE charset prefixing it with a BOM

  94. def utf16Decode(implicit trace: Trace): ZPipeline[Any, CharacterCodingException, Byte, String]

    Permalink

    Creates a pipeline that converts a stream of bytes into a stream of strings using the UTF_16 charset

  95. def utf16Encode(implicit trace: Trace): ZPipeline[Any, CharacterCodingException, String, Byte]

    Permalink

    Creates a pipeline that converts a stream of strings into a stream of bytes using the UTF_16BE charset prefixing it with a BOM

  96. def utf16LEDecode(implicit trace: Trace): ZPipeline[Any, CharacterCodingException, Byte, String]

    Permalink

    Creates a pipeline that converts a stream of bytes into a stream of strings using the UTF_16LE charset

  97. def utf16LEEncode(implicit trace: Trace): ZPipeline[Any, CharacterCodingException, String, Byte]

    Permalink

    Creates a pipeline that converts a stream of strings into a stream of bytes using the UTF_16LE charset, without adding a BOM

  98. def utf16LEWithBomEncode(implicit trace: Trace): ZPipeline[Any, CharacterCodingException, String, Byte]

    Permalink

    Creates a pipeline that converts a stream of strings into a stream of bytes using the UTF_16LE charset prefixing it with a BOM

  99. def utf16WithBomEncode(implicit trace: Trace): ZPipeline[Any, CharacterCodingException, String, Byte]

    Permalink

    Creates a pipeline that converts a stream of strings into a stream of bytes using the UTF_16 charset prefixing it with a BOM

  100. def utf32BEDecode(implicit trace: Trace): ZPipeline[Any, CharacterCodingException, Byte, String]

    Permalink

    Creates a pipeline that converts a stream of bytes into a stream of strings using the UTF_32BE charset

  101. def utf32BEEncode(implicit trace: Trace): ZPipeline[Any, CharacterCodingException, String, Byte]

    Permalink

    Creates a pipeline that converts a stream of strings into a stream of bytes using the UTF_32BE charset, without adding a BOM

  102. def utf32BEWithBomEncode(implicit trace: Trace): ZPipeline[Any, CharacterCodingException, String, Byte]

    Permalink

    Creates a pipeline that converts a stream of strings into a stream of bytes using the UTF_32BE charset prefixing it with a BOM

  103. def utf32Decode(implicit trace: Trace): ZPipeline[Any, CharacterCodingException, Byte, String]

    Permalink

    Creates a pipeline that converts a stream of bytes into a stream of strings using the UTF_32 charset

  104. def utf32Encode(implicit trace: Trace): ZPipeline[Any, CharacterCodingException, String, Byte]

    Permalink

    Creates a pipeline that converts a stream of strings into a stream of bytes using the UTF_32BE charset, without adding a BOM

  105. def utf32LEDecode(implicit trace: Trace): ZPipeline[Any, CharacterCodingException, Byte, String]

    Permalink

    Creates a pipeline that converts a stream of bytes into a stream of strings using the UTF_32LE charset

  106. def utf32LEEncode(implicit trace: Trace): ZPipeline[Any, CharacterCodingException, String, Byte]

    Permalink

    Creates a pipeline that converts a stream of strings into a stream of bytes using the UTF_32LE charset, without adding a BOM

  107. def utf32LEWithBomEncode(implicit trace: Trace): ZPipeline[Any, CharacterCodingException, String, Byte]

    Permalink

    Creates a pipeline that converts a stream of strings into a stream of bytes using the UTF_32LE charset prefixing it with a BOM

  108. def utf32WithBomEncode(implicit trace: Trace): ZPipeline[Any, CharacterCodingException, String, Byte]

    Permalink

    Creates a pipeline that converts a stream of strings into a stream of bytes using the UTF_32BE charset prefixing it with a BOM

  109. def utf8Decode(implicit trace: Trace): ZPipeline[Any, CharacterCodingException, Byte, String]

    Permalink

    Creates a pipeline that converts a stream of bytes into a stream of strings using the UTF_8 charset

  110. def utf8Encode(implicit trace: Trace): ZPipeline[Any, CharacterCodingException, String, Byte]

    Permalink

    Creates a pipeline that converts a stream of strings into a stream of bytes using the UTF_8 charset, without adding a BOM

  111. def utf8WithBomEncode(implicit trace: Trace): ZPipeline[Any, CharacterCodingException, String, Byte]

    Permalink

    Creates a pipeline that converts a stream of strings into a stream of bytes using the UTF_8 charset prefixing it with a BOM

  112. def utfDecode(implicit trace: Trace): ZPipeline[Any, CharacterCodingException, Byte, String]

    Permalink

    utfDecode determines the right encoder to use based on the Byte Order Mark (BOM).

    utfDecode determines the right encoder to use based on the Byte Order Mark (BOM). If it doesn't detect one, it defaults to utf8Decode. In the case of utf16 and utf32 without BOM, utf16Decode and utf32Decode should be used instead as both default to their own default decoder respectively.

  113. final def wait(): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  114. final def wait(arg0: Long, arg1: Int): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  115. final def wait(arg0: Long): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  116. def zipWithIndex[In](implicit trace: Trace): ZPipeline[Any, Nothing, In, (In, Long)]

    Permalink

    Zips this pipeline together with the index of elements.

  117. def zipWithNext[In](implicit trace: Trace): ZPipeline[Any, Nothing, In, (In, Option[In])]

    Permalink

    Zips each element with the next element if present.

  118. def zipWithPrevious[In](implicit trace: Trace): ZPipeline[Any, Nothing, In, (Option[In], In)]

    Permalink
  119. def zipWithPreviousAndNext[In](implicit trace: Trace): ZPipeline[Any, Nothing, In, (Option[In], In, Option[In])]

    Permalink

Inherited from ZPipelinePlatformSpecificConstructors

Inherited from AnyRef

Inherited from Any

Ungrouped