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 aggregateAsync[Env, Err, In, Out](sink: ⇒ ZSink[Env, Err, In, In, Out])(implicit trace: Trace): ZPipeline[Env, Err, In, Out]

    Permalink

    Aggregates elements of this stream using the provided sink for as long as the downstream operators on the stream are busy.

    Aggregates elements of this stream using the provided sink for as long as the downstream operators on the stream are busy.

    This operator divides the stream into two asynchronous "islands". Operators upstream of this operator run on one fiber, while downstream operators run on another. Whenever the downstream fiber is busy processing elements, the upstream fiber will feed elements into the sink until it signals completion.

    Any sink can be used here, but see ZSink.foldWeightedZIO and ZSink.foldUntilZIO for sinks that cover the common usecases.

  5. def aggregateAsyncWithin[Env, Err, In, Out](sink: ⇒ ZSink[Env, Err, In, In, Out], schedule: ⇒ Schedule[Env, Option[Out], Any])(implicit trace: Trace): ZPipeline[Env, Err, In, Out]

    Permalink

    Like aggregateAsyncWithinEither, but only returns the Right results.

  6. def aggregateAsyncWithinEither[Env, Err, In, Out, Out2](sink: ⇒ ZSink[Env, Err, In, In, Out], schedule: ⇒ Schedule[Env, Option[Out], Out2])(implicit trace: Trace): ZPipeline[Env, Err, In, Either[Out2, Out]]

    Permalink

    Aggregates elements using the provided sink until it completes, or until the delay signalled by the schedule has passed.

    Aggregates elements using the provided sink until it completes, or until the delay signalled by the schedule has passed.

    This operator divides the stream into two asynchronous islands. Operators upstream of this operator run on one fiber, while downstream operators run on another. Elements will be aggregated by the sink until the downstream fiber pulls the aggregated value, or until the schedule's delay has passed.

    Aggregated elements will be fed into the schedule to determine the delays between pulls.

  7. def append[In](values: ⇒ Chunk[In])(implicit trace: Trace): ZPipeline[Any, Nothing, In, In]

    Permalink
  8. 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)
  9. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  10. 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.

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

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

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

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

    Permalink

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

  15. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  16. 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 }
  17. def collectLeft[Err, A, B](implicit trace: Trace): ZPipeline[Any, Err, Either[A, B], A]

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

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

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

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

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

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

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

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

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

    Permalink
  27. def debounce[In](d: ⇒ zio.Duration)(implicit trace: Trace): ZPipeline[Any, Nothing, In, In]

    Permalink

    Delays the emission of values by holding new values for a set duration.

    Delays the emission of values by holding new values for a set duration. If no new values arrive during that time the value is emitted, however if a new value is received during the holding period the previous value is discarded and the process is repeated with the new value.

    This operator is useful if you have a stream of "bursty" events which eventually settle down and you only need the final event of the burst.

    Example:
    1. A search engine may only want to initiate a search after a user has paused typing so as to not prematurely recommend results.

  28. 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

  29. 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

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

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

    Permalink

    Creates a pipeline that drops n elements.

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

    Permalink
  33. 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)
  34. 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.

  35. 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)
  36. 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.

  37. 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

  38. 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

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

    Permalink

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

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

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

    Permalink
    Definition Classes
    AnyRef → Any
  42. 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.

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

    Permalink
  44. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  45. 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.

  46. 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.

  47. 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.

  48. 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.

  49. def flattenTake[Err, Out](implicit trace: Trace): ZPipeline[Any, Err, Take[Err, Out], Out]

    Permalink

    Creates a pipeline that flattens a stream of takes.

  50. 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.

  51. def fromFunction[Env, Err, In, Out](f: (ZStream[Any, Nothing, In]) ⇒ ZStream[Env, Err, Out])(implicit trace: Trace): ZPipeline[Env, Err, In, Out]

    Permalink

    Constructs a pipeline from a stream transformation function.

  52. 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.

  53. 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.

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

    Permalink
    Definition Classes
    AnyRef → Any
  55. 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.

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

    Permalink
  57. def groupedWithin[In](chunkSize: ⇒ Int, within: ⇒ zio.Duration)(implicit trace: Trace): ZPipeline[Any, Nothing, In, Chunk[In]]

    Permalink

    Partitions the stream with the specified chunkSize or until the specified duration has passed, whichever is satisfied first.

  58. def hashCode(): Int

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

    Permalink

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

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

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

    Permalink
  62. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  63. 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

  64. 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

  65. 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.

  66. 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.

  67. 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.

  68. 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.

  69. 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.

  70. 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.

  71. 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.

  72. def mapZIOPar[Env, Err, In, Out](n: ⇒ Int)(f: (In) ⇒ ZIO[Env, Err, Out])(implicit trace: Trace): ZPipeline[Env, Err, In, Out]

    Permalink

    Maps over elements of the stream with the specified effectful function, executing up to n invocations of f concurrently.

    Maps over elements of the stream with the specified effectful function, executing up to n invocations of f concurrently. Transformed elements will be emitted in the original order.

    Note

    This combinator destroys the chunking structure. It's recommended to use rechunk afterwards.

  73. def mapZIOParUnordered[Env, Err, In, Out](n: ⇒ Int)(f: (In) ⇒ ZIO[Env, Err, Out])(implicit trace: Trace): ZPipeline[Env, Err, In, Out]

    Permalink

    Maps over elements of the stream with the specified effectful function, executing up to n invocations of f concurrently.

    Maps over elements of the stream with the specified effectful function, executing up to n invocations of f concurrently. The element order is not enforced by this combinator, and elements may be reordered.

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

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

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

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

    Permalink

    Emits the provided chunk before emitting any other value.

  78. 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.

  79. 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.

  80. 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.

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

    Permalink

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

  82. 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).

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

    Permalink

    Splits strings on a delimiter.

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

    Permalink

    Splits strings on a delimiter.

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

    Permalink

    Lazily constructs a pipeline.

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

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

    Permalink

    Creates a pipeline that takes n elements.

  88. 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.

  89. 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.

  90. 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.

  91. 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.

  92. 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.

  93. 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.

  94. 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.

  95. def toString(): String

    Permalink
    Definition Classes
    AnyRef → Any
  96. 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.

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

    Permalink

    Created a pipeline produced from a scoped effect.

  98. 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

  99. 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

  100. 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

  101. 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

  102. 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

  103. 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

  104. 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

  105. 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

  106. 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

  107. 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

  108. 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

  109. 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

  110. 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

  111. 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

  112. 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

  113. 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

  114. 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

  115. 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

  116. 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

  117. 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

  118. 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

  119. 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

  120. 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

  121. 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.

  122. final def wait(): Unit

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

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

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

    Permalink

    Zips this pipeline together with the index of elements.

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

    Permalink

    Zips each element with the next element if present.

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

    Permalink
  128. 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