Return-Path: X-Original-To: archive-asf-public-internal@cust-asf2.ponee.io Delivered-To: archive-asf-public-internal@cust-asf2.ponee.io Received: from cust-asf.ponee.io (cust-asf.ponee.io [163.172.22.183]) by cust-asf2.ponee.io (Postfix) with ESMTP id 96202200ACA for ; Thu, 19 May 2016 02:01:55 +0200 (CEST) Received: by cust-asf.ponee.io (Postfix) id 94A05160A15; Thu, 19 May 2016 00:01:55 +0000 (UTC) Delivered-To: archive-asf-public@cust-asf.ponee.io Received: from mail.apache.org (hermes.apache.org [140.211.11.3]) by cust-asf.ponee.io (Postfix) with SMTP id 2C8AA160A00 for ; Thu, 19 May 2016 02:01:53 +0200 (CEST) Received: (qmail 32921 invoked by uid 500); 19 May 2016 00:01:51 -0000 Mailing-List: contact commits-help@kafka.apache.org; run by ezmlm Precedence: bulk List-Help: List-Unsubscribe: List-Post: List-Id: Reply-To: dev@kafka.apache.org Delivered-To: mailing list commits@kafka.apache.org Received: (qmail 32553 invoked by uid 99); 19 May 2016 00:01:51 -0000 Received: from git1-us-west.apache.org (HELO git1-us-west.apache.org) (140.211.11.23) by apache.org (qpsmtpd/0.29) with ESMTP; Thu, 19 May 2016 00:01:51 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id 4B7FDDFC13; Thu, 19 May 2016 00:01:51 +0000 (UTC) Content-Type: text/plain; charset="us-ascii" MIME-Version: 1.0 Content-Transfer-Encoding: 7bit From: ijuma@apache.org To: commits@kafka.apache.org Date: Thu, 19 May 2016 00:01:57 -0000 Message-Id: In-Reply-To: References: X-Mailer: ASF-Git Admin Mailer Subject: [07/51] [partial] kafka-site git commit: Update javadoc for 0.10 to include connect and streams archived-at: Thu, 19 May 2016 00:01:55 -0000 http://git-wip-us.apache.org/repos/asf/kafka-site/blob/af5a933b/0100/javadoc/org/apache/kafka/streams/kstream/KeyValueMapper.html ---------------------------------------------------------------------- diff --git a/0100/javadoc/org/apache/kafka/streams/kstream/KeyValueMapper.html b/0100/javadoc/org/apache/kafka/streams/kstream/KeyValueMapper.html new file mode 100644 index 0000000..8e9d786 --- /dev/null +++ b/0100/javadoc/org/apache/kafka/streams/kstream/KeyValueMapper.html @@ -0,0 +1,215 @@ + + + + + +KeyValueMapper (kafka 0.10.0.0 API) + + + + + + + + + + + +
+
org.apache.kafka.streams.kstream
+

Interface KeyValueMapper<K,V,R>

+
+
+
+
    +
  • +
    Type Parameters:
    K - original key type
    V - original value type
    R - mapped value type
    +
    +
    +
    public interface KeyValueMapper<K,V,R>
    +
    The KeyValueMapper interface for mapping a key-value pair to a new value (could be another key-value pair).
    +
  • +
+
+
+
    +
  • + +
      +
    • + + +

      Method Summary

      + + + + + + + + + + +
      Methods 
      Modifier and TypeMethod and Description
      Rapply(K key, + V value) +
      Map a record with the given key and value to a new value.
      +
      +
    • +
    +
  • +
+
+
+
    +
  • + +
      +
    • + + +

      Method Detail

      + + + + + +
        +
      • +

        apply

        +
        R apply(K key,
        +      V value)
        +
        Map a record with the given key and value to a new value.
        +
        Parameters:
        key - the key of the record
        value - the value of the record
        +
        Returns:
        the new value
        +
      • +
      +
    • +
    +
  • +
+
+
+ + + + + + + http://git-wip-us.apache.org/repos/asf/kafka-site/blob/af5a933b/0100/javadoc/org/apache/kafka/streams/kstream/Predicate.html ---------------------------------------------------------------------- diff --git a/0100/javadoc/org/apache/kafka/streams/kstream/Predicate.html b/0100/javadoc/org/apache/kafka/streams/kstream/Predicate.html new file mode 100644 index 0000000..fef728d --- /dev/null +++ b/0100/javadoc/org/apache/kafka/streams/kstream/Predicate.html @@ -0,0 +1,215 @@ + + + + + +Predicate (kafka 0.10.0.0 API) + + + + + + + + + + + +
+
org.apache.kafka.streams.kstream
+

Interface Predicate<K,V>

+
+
+
+
    +
  • +
    Type Parameters:
    K - key type
    V - value type
    +
    +
    +
    public interface Predicate<K,V>
    +
    The Predicate interface represents a predicate (boolean-valued function) of a key-value pair.
    +
  • +
+
+
+
    +
  • + +
      +
    • + + +

      Method Summary

      + + + + + + + + + + +
      Methods 
      Modifier and TypeMethod and Description
      booleantest(K key, + V value) +
      Test if the record with the given key and value satisfies the predicate.
      +
      +
    • +
    +
  • +
+
+
+
    +
  • + +
      +
    • + + +

      Method Detail

      + + + + + +
        +
      • +

        test

        +
        boolean test(K key,
        +           V value)
        +
        Test if the record with the given key and value satisfies the predicate.
        +
        Parameters:
        key - the key of the record
        value - the value of the record
        +
        Returns:
        return true if the key-value pair satisfies the predicate—false otherwise
        +
      • +
      +
    • +
    +
  • +
+
+
+ + + + + + + http://git-wip-us.apache.org/repos/asf/kafka-site/blob/af5a933b/0100/javadoc/org/apache/kafka/streams/kstream/Reducer.html ---------------------------------------------------------------------- diff --git a/0100/javadoc/org/apache/kafka/streams/kstream/Reducer.html b/0100/javadoc/org/apache/kafka/streams/kstream/Reducer.html new file mode 100644 index 0000000..3d6de20 --- /dev/null +++ b/0100/javadoc/org/apache/kafka/streams/kstream/Reducer.html @@ -0,0 +1,215 @@ + + + + + +Reducer (kafka 0.10.0.0 API) + + + + + + + + + + + +
+
org.apache.kafka.streams.kstream
+

Interface Reducer<V>

+
+
+
+
    +
  • +
    Type Parameters:
    V - value type
    +
    +
    +
    public interface Reducer<V>
    +
    The Reducer interface for combining two values of the same type into a new value.
    +
  • +
+
+
+
    +
  • + +
      +
    • + + +

      Method Summary

      + + + + + + + + + + +
      Methods 
      Modifier and TypeMethod and Description
      Vapply(V value1, + V value2) +
      Aggregate the two given values into a single one.
      +
      +
    • +
    +
  • +
+
+
+
    +
  • + +
      +
    • + + +

      Method Detail

      + + + + + +
        +
      • +

        apply

        +
        V apply(V value1,
        +      V value2)
        +
        Aggregate the two given values into a single one.
        +
        Parameters:
        value1 - the first value for the aggregation
        value2 - the second value for the aggregation
        +
        Returns:
        the aggregated value
        +
      • +
      +
    • +
    +
  • +
+
+
+ + + + + + + http://git-wip-us.apache.org/repos/asf/kafka-site/blob/af5a933b/0100/javadoc/org/apache/kafka/streams/kstream/TimeWindows.html ---------------------------------------------------------------------- diff --git a/0100/javadoc/org/apache/kafka/streams/kstream/TimeWindows.html b/0100/javadoc/org/apache/kafka/streams/kstream/TimeWindows.html new file mode 100644 index 0000000..973c23a --- /dev/null +++ b/0100/javadoc/org/apache/kafka/streams/kstream/TimeWindows.html @@ -0,0 +1,404 @@ + + + + + +TimeWindows (kafka 0.10.0.0 API) + + + + + + + + + + + +
+
org.apache.kafka.streams.kstream
+

Class TimeWindows

+
+
+ +
+
    +
  • +
    +
    +
    public class TimeWindows
    +extends Windows<TimeWindow>
    +
    The time-based window specifications used for aggregations. +

    + The semantics of a time-based window are: Every T1 (advance) time-units, compute the aggregate total for T2 (size) time-units. +

      +
    • If advance < size a hopping windows is defined:
      + it discretize a stream into overlapping windows, which implies that a record maybe contained in one and or more "adjacent" windows.
    • +
    • If advance == size a tumbling window is defined:
      + it discretize a stream into non-overlapping windows, which implies that a record is only ever contained in one and only one tumbling window.
    • +
    +
  • +
+
+
+
    +
  • + +
      +
    • + + +

      Field Summary

      + + + + + + + + + + + + + + +
      Fields 
      Modifier and TypeField and Description
      longadvance +
      The size of the window's advance interval, i.e.
      +
      longsize +
      The size of the window, i.e.
      +
      + +
    • +
    + +
      +
    • + + +

      Method Summary

      + + + + + + + + + + + + + + + + + + + + + + + + + + +
      Methods 
      Modifier and TypeMethod and Description
      TimeWindowsadvanceBy(long interval) +
      Returns a window definition with the original size, but advance ("hop") the window by the given + interval, which specifies by how much a window moves forward relative to the previous one.
      +
      booleanequals(Object o) 
      inthashCode() 
      static TimeWindowsof(String name, + long size) +
      Returns a window definition with the given window size, and with the advance interval being + equal to the window size.
      +
      Map<Long,TimeWindow>windowsFor(long timestamp) +
      Creates all windows that contain the provided timestamp.
      +
      + + +
    • +
    +
  • +
+
+
+
    +
  • + +
      +
    • + + +

      Field Detail

      + + + +
        +
      • +

        size

        +
        public final long size
        +
        The size of the window, i.e. how long a window lasts. + The window size's effective time unit is determined by the semantics of the topology's + configured TimestampExtractor.
        +
      • +
      + + + +
        +
      • +

        advance

        +
        public final long advance
        +
        The size of the window's advance interval, i.e. by how much a window moves forward relative + to the previous one. The interval's effective time unit is determined by the semantics of + the topology's configured TimestampExtractor.
        +
      • +
      +
    • +
    + +
      +
    • + + +

      Method Detail

      + + + +
        +
      • +

        of

        +
        public static TimeWindows of(String name,
        +             long size)
        +
        Returns a window definition with the given window size, and with the advance interval being + equal to the window size. Think: [N * size, N * size + size), with N denoting the N-th + window. + + This provides the semantics of tumbling windows, which are fixed-sized, gap-less, + non-overlapping windows. Tumbling windows are a specialization of hopping windows.
        +
        Parameters:
        name - The name of the window. Must not be null or empty.
        size - The size of the window, with the requirement that size > 0. + The window size's effective time unit is determined by the semantics of the + topology's configured TimestampExtractor.
        +
        Returns:
        a new window definition
        +
      • +
      + + + +
        +
      • +

        advanceBy

        +
        public TimeWindows advanceBy(long interval)
        +
        Returns a window definition with the original size, but advance ("hop") the window by the given + interval, which specifies by how much a window moves forward relative to the previous one. + Think: [N * advanceInterval, N * advanceInterval + size), with N denoting the N-th window. + + This provides the semantics of hopping windows, which are fixed-sized, overlapping windows.
        +
        Parameters:
        interval - The advance interval ("hop") of the window, with the requirement that + 0 < interval ≤ size. The interval's effective time unit is + determined by the semantics of the topology's configured + TimestampExtractor.
        +
        Returns:
        a new window definition
        +
      • +
      + + + +
        +
      • +

        windowsFor

        +
        public Map<Long,TimeWindow> windowsFor(long timestamp)
        +
        Description copied from class: Windows
        +
        Creates all windows that contain the provided timestamp.
        +
        +
        Specified by:
        +
        windowsFor in class Windows<TimeWindow>
        +
        Parameters:
        timestamp - the timestamp window should get created for
        +
        Returns:
        a map of windowStartTimestamp -> Window entries
        +
      • +
      + + + +
        +
      • +

        equals

        +
        public final boolean equals(Object o)
        +
        +
        Overrides:
        +
        equals in class Object
        +
        +
      • +
      + + + +
        +
      • +

        hashCode

        +
        public int hashCode()
        +
        +
        Overrides:
        +
        hashCode in class Object
        +
        +
      • +
      +
    • +
    +
  • +
+
+
+ + + + + + + http://git-wip-us.apache.org/repos/asf/kafka-site/blob/af5a933b/0100/javadoc/org/apache/kafka/streams/kstream/Transformer.html ---------------------------------------------------------------------- diff --git a/0100/javadoc/org/apache/kafka/streams/kstream/Transformer.html b/0100/javadoc/org/apache/kafka/streams/kstream/Transformer.html new file mode 100644 index 0000000..98a60e7 --- /dev/null +++ b/0100/javadoc/org/apache/kafka/streams/kstream/Transformer.html @@ -0,0 +1,272 @@ + + + + + +Transformer (kafka 0.10.0.0 API) + + + + + + + + + + + +
+
org.apache.kafka.streams.kstream
+

Interface Transformer<K,V,R>

+
+
+
+
    +
  • +
    Type Parameters:
    K - key type
    V - value type
    R - return type
    +
    +
    +
    public interface Transformer<K,V,R>
    +
    A stateful Transformer interface for transform a key-value pair into a new value.
    +
  • +
+
+
+
    +
  • + +
      +
    • + + +

      Method Summary

      + + + + + + + + + + + + + + + + + + + + + + +
      Methods 
      Modifier and TypeMethod and Description
      voidclose() +
      Close this processor and clean up any resources.
      +
      voidinit(ProcessorContext context) +
      Initialize this transformer with the given context.
      +
      Rpunctuate(long timestamp) +
      Perform any periodic operations and possibly generate a key, if this processor schedule itself with the context + during initialization.
      +
      Rtransform(K key, + V value) +
      Transform the record with the given key and value.
      +
      +
    • +
    +
  • +
+
+
+
    +
  • + +
      +
    • + + +

      Method Detail

      + + + +
        +
      • +

        init

        +
        void init(ProcessorContext context)
        +
        Initialize this transformer with the given context. The framework ensures this is called once per processor when the topology + that contains it is initialized. +

        + If this transformer is to be called periodically by the framework, then this method should + schedule itself with the provided context.

        +
        Parameters:
        context - the context; may not be null
        +
      • +
      + + + + + +
        +
      • +

        transform

        +
        R transform(K key,
        +          V value)
        +
        Transform the record with the given key and value.
        +
        Parameters:
        key - the key for the record
        value - the value for the record
        +
        Returns:
        new value; if null no key-value pair will be forwarded to down stream
        +
      • +
      + + + +
        +
      • +

        punctuate

        +
        R punctuate(long timestamp)
        +
        Perform any periodic operations and possibly generate a key, if this processor schedule itself with the context + during initialization.
        +
        Parameters:
        timestamp - the stream time when this method is being called
        +
        Returns:
        new value; if null it will not be forwarded to down stream
        +
      • +
      + + + +
        +
      • +

        close

        +
        void close()
        +
        Close this processor and clean up any resources.
        +
      • +
      +
    • +
    +
  • +
+
+
+ + + + + + + http://git-wip-us.apache.org/repos/asf/kafka-site/blob/af5a933b/0100/javadoc/org/apache/kafka/streams/kstream/TransformerSupplier.html ---------------------------------------------------------------------- diff --git a/0100/javadoc/org/apache/kafka/streams/kstream/TransformerSupplier.html b/0100/javadoc/org/apache/kafka/streams/kstream/TransformerSupplier.html new file mode 100644 index 0000000..dc5ab35 --- /dev/null +++ b/0100/javadoc/org/apache/kafka/streams/kstream/TransformerSupplier.html @@ -0,0 +1,209 @@ + + + + + +TransformerSupplier (kafka 0.10.0.0 API) + + + + + + + + + + + +
+
org.apache.kafka.streams.kstream
+

Interface TransformerSupplier<K,V,R>

+
+
+
+ +
+
+
    +
  • + + +
  • +
+
+
+ +
+
+ + + + + + + http://git-wip-us.apache.org/repos/asf/kafka-site/blob/af5a933b/0100/javadoc/org/apache/kafka/streams/kstream/UnlimitedWindows.html ---------------------------------------------------------------------- diff --git a/0100/javadoc/org/apache/kafka/streams/kstream/UnlimitedWindows.html b/0100/javadoc/org/apache/kafka/streams/kstream/UnlimitedWindows.html new file mode 100644 index 0000000..7104d35 --- /dev/null +++ b/0100/javadoc/org/apache/kafka/streams/kstream/UnlimitedWindows.html @@ -0,0 +1,356 @@ + + + + + +UnlimitedWindows (kafka 0.10.0.0 API) + + + + + + + + + + + +
+
org.apache.kafka.streams.kstream
+

Class UnlimitedWindows

+
+
+ +
+
    +
  • +
    +
    +
    public class UnlimitedWindows
    +extends Windows<UnlimitedWindow>
    +
    The unlimited window specifications.
    +
  • +
+
+
+ +
+
+
    +
  • + +
      +
    • + + +

      Field Detail

      + + + +
        +
      • +

        start

        +
        public final long start
        +
        The start timestamp of the window.
        +
      • +
      +
    • +
    + +
      +
    • + + +

      Method Detail

      + + + +
        +
      • +

        of

        +
        public static UnlimitedWindows of(String name)
        +
        Return an unlimited window starting at timestamp zero.
        +
      • +
      + + + +
        +
      • +

        startOn

        +
        public UnlimitedWindows startOn(long start)
        +
        Return a new unlimited window for the specified start timestamp.
        +
        Parameters:
        start - the window start time
        +
        Returns:
        a new unlimited window that starts at start
        +
      • +
      + + + +
        +
      • +

        windowsFor

        +
        public Map<Long,UnlimitedWindow> windowsFor(long timestamp)
        +
        Description copied from class: Windows
        +
        Creates all windows that contain the provided timestamp.
        +
        +
        Specified by:
        +
        windowsFor in class Windows<UnlimitedWindow>
        +
        Parameters:
        timestamp - the timestamp window should get created for
        +
        Returns:
        a map of windowStartTimestamp -> Window entries
        +
      • +
      + + + +
        +
      • +

        equals

        +
        public final boolean equals(Object o)
        +
        +
        Overrides:
        +
        equals in class Object
        +
        +
      • +
      + + + +
        +
      • +

        hashCode

        +
        public int hashCode()
        +
        +
        Overrides:
        +
        hashCode in class Object
        +
        +
      • +
      +
    • +
    +
  • +
+
+
+ + + + + + +