You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@datasketches.apache.org by al...@apache.org on 2019/07/30 22:17:37 UTC

[incubator-datasketches-cpp] branch hll_cleanup updated: removed unused stuff

This is an automated email from the ASF dual-hosted git repository.

alsay pushed a commit to branch hll_cleanup
in repository https://gitbox.apache.org/repos/asf/incubator-datasketches-cpp.git


The following commit(s) were added to refs/heads/hll_cleanup by this push:
     new f31be15  removed unused stuff
f31be15 is described below

commit f31be158a1e4434501ba8d7cc311c8c5a70be678
Author: AlexanderSaydakov <Al...@users.noreply.github.com>
AuthorDate: Tue Jul 30 15:17:29 2019 -0700

    removed unused stuff
---
 hll/include/Conversions-internal.hpp | 127 -----------------------------
 hll/include/Conversions.hpp          |  44 ----------
 hll/include/Hll4Array.hpp            |   4 -
 hll/include/Hll6Array.hpp            |   2 -
 hll/include/Hll8Array.hpp            |   4 +-
 hll/include/HllArray-internal.hpp    |   1 -
 hll/include/HllArray.hpp             |   6 --
 hll/include/HllSketch-internal.hpp   |   2 -
 hll/include/HllSketch.hpp            | 122 ---------------------------
 hll/include/HllSketchImpl.hpp        |   5 --
 hll/include/HllSketchImplFactory.hpp |   8 --
 hll/include/HllUnion.hpp             | 154 -----------------------------------
 hll/include/hll.private.hpp          |   2 -
 13 files changed, 1 insertion(+), 480 deletions(-)

diff --git a/hll/include/Conversions-internal.hpp b/hll/include/Conversions-internal.hpp
deleted file mode 100644
index b42465c..0000000
--- a/hll/include/Conversions-internal.hpp
+++ /dev/null
@@ -1,127 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-#ifndef _CONVERSIONS_INTERNAL_HPP_
-#define _CONVERSIONS_INTERNAL_HPP_
-
-#include "Conversions.hpp"
-#include "HllUtil.hpp"
-#include "HllArray.hpp"
-
-#include <memory>
-
-namespace datasketches {
-
-Hll4Array* Conversions::convertToHll4(const HllArray& srcHllArr) {
-  const int lgConfigK = srcHllArr.getLgConfigK();
-  Hll4Array* hll4Array = new Hll4Array(lgConfigK);
-  hll4Array->putOutOfOrderFlag(srcHllArr.isOutOfOrderFlag());
-
-  // 1st pass: compute starting curMin and numAtCurMin
-  int pairVals = curMinAndNum(srcHllArr);
-  int curMin = HllUtil<>::getValue(pairVals);
-  int numAtCurMin = HllUtil<>::getLow26(pairVals);
-
-  // 2nd pass: must know curMin.
-  // Populate KxQ registers, build AuxHashMap if needed
-  std::unique_ptr<PairIterator> itr = srcHllArr.getIterator();
-  // nothing allocated, may be null
-  AuxHashMap* auxHashMap = srcHllArr.getAuxHashMap();
-
-  while (itr->nextValid()) {
-    const int slotNo = itr->getIndex();
-    const int actualValue = itr->getValue();
-    HllArray::hipAndKxQIncrementalUpdate(*hll4Array, 0, actualValue);
-    if (actualValue >= (curMin + 15)) {
-      hll4Array->putSlot(slotNo, HllUtil<>::AUX_TOKEN);
-      if (auxHashMap == nullptr) {
-        auxHashMap = new AuxHashMap(HllUtil<>::LG_AUX_ARR_INTS[lgConfigK], lgConfigK);
-        hll4Array->putAuxHashMap(auxHashMap);
-      }
-      auxHashMap->mustAdd(slotNo, actualValue);
-    } else {
-      hll4Array->putSlot(slotNo, actualValue - curMin);
-    }
-  }
-
-  hll4Array->putCurMin(curMin);
-  hll4Array->putNumAtCurMin(numAtCurMin);
-  hll4Array->putHipAccum(srcHllArr.getHipAccum());
-
-  return hll4Array;
-}
-
-int Conversions::curMinAndNum(const HllArray& hllArr) {
-  int curMin = 64;
-  int numAtCurMin = 0;
-  std::unique_ptr<PairIterator> itr = hllArr.getIterator();
-  while (itr->nextAll()) {
-    int v = itr->getValue();
-    if (v < curMin) {
-      curMin = v;
-      numAtCurMin = 1;
-    } else if (v == curMin) {
-      ++numAtCurMin;
-    }
-  }
-
-  return HllUtil<>::pair(numAtCurMin, curMin);
-}
-
-Hll6Array* Conversions::convertToHll6(const HllArray& srcHllArr) {
-  const int lgConfigK = srcHllArr.getLgConfigK();
-  Hll6Array* hll6Array = new Hll6Array(lgConfigK);
-  hll6Array->putOutOfOrderFlag(srcHllArr.isOutOfOrderFlag());
-
-  int numZeros = 1 << lgConfigK;
-  std::unique_ptr<PairIterator> itr = srcHllArr.getIterator();
-  while (itr->nextAll()) {
-    if (itr->getValue() != HllUtil<>::EMPTY) {
-      --numZeros;
-      hll6Array->couponUpdate(itr->getPair());
-    }
-  }
-
-  hll6Array->putNumAtCurMin(numZeros);
-  hll6Array->putHipAccum(srcHllArr.getHipAccum());
-  return hll6Array;
-}
-
-Hll8Array* Conversions::convertToHll8(const HllArray& srcHllArr) {
-  const int lgConfigK = srcHllArr.getLgConfigK();
-  Hll8Array* hll8Array = new Hll8Array(lgConfigK);
-  hll8Array->putOutOfOrderFlag(srcHllArr.isOutOfOrderFlag());
-
-  int numZeros = 1 << lgConfigK;
-  std::unique_ptr<PairIterator> itr = srcHllArr.getIterator();
-  while (itr->nextAll()) {
-    if (itr->getValue() != HllUtil<>::EMPTY) {
-      --numZeros;
-      hll8Array->couponUpdate(itr->getPair());
-    }
-  }
-
-  hll8Array->putNumAtCurMin(numZeros);
-  hll8Array->putHipAccum(srcHllArr.getHipAccum());
-  return hll8Array;
-}
-
-}
-
-#endif // _CONVERSIONS_INTERNAL_HPP_
\ No newline at end of file
diff --git a/hll/include/Conversions.hpp b/hll/include/Conversions.hpp
deleted file mode 100644
index 8f8578e..0000000
--- a/hll/include/Conversions.hpp
+++ /dev/null
@@ -1,44 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-#ifndef _CONVERSIONS_HPP_
-#define _CONVERSIONS_HPP_
-/*
-//#include "CouponMode.hpp"
-#include "Hll4Array.hpp"
-#include "Hll6Array.hpp"
-#include "Hll8Array.hpp"
-
-namespace datasketches {
-
-class Conversions {
-public:
-  static Hll4Array* convertToHll4(const HllArray& srcHllArr);
-  static Hll6Array* convertToHll6(const HllArray& srcHllArr);
-  static Hll8Array* convertToHll8(const HllArray& srcHllArr);
-
-private:
-  static int curMinAndNum(const HllArray& hllArr);
-};
-
-}
-*/
-//#include "Conversions-internal.hpp"
-
-#endif // _CONVERSIONS_HPP_
diff --git a/hll/include/Hll4Array.hpp b/hll/include/Hll4Array.hpp
index 2f84546..5ddc012 100644
--- a/hll/include/Hll4Array.hpp
+++ b/hll/include/Hll4Array.hpp
@@ -40,8 +40,6 @@ class Hll4Array final : public HllArray<A> {
 
     virtual Hll4Array* copy() const;
 
-    //virtual std::unique_ptr<PairIterator<A>> getIterator() const;
-    //virtual std::unique_ptr<PairIterator<A>> getAuxIterator() const;
     virtual PairIterator_with_deleter<A> getIterator() const;
     virtual PairIterator_with_deleter<A> getAuxIterator() const;
 
@@ -80,6 +78,4 @@ class Hll4Iterator : public HllPairIterator<A> {
 
 }
 
-//#include "Hll4Array-internal.hpp"
-
 #endif /* _HLL4ARRAY_HPP_ */
diff --git a/hll/include/Hll6Array.hpp b/hll/include/Hll6Array.hpp
index bd9bf18..e45aac4 100644
--- a/hll/include/Hll6Array.hpp
+++ b/hll/include/Hll6Array.hpp
@@ -67,6 +67,4 @@ class Hll6Iterator : public HllPairIterator<A> {
 
 }
 
-//#include "Hll6Array-internal.hpp"
-
 #endif /* _HLL6ARRAY_HPP_ */
diff --git a/hll/include/Hll8Array.hpp b/hll/include/Hll8Array.hpp
index b334e1d..77372e7 100644
--- a/hll/include/Hll8Array.hpp
+++ b/hll/include/Hll8Array.hpp
@@ -66,6 +66,4 @@ class Hll8Iterator : public HllPairIterator<A> {
 
 }
 
-//#include "Hll8Array-internal.hpp"
-
-#endif /* _HLL8ARRAY_HPP_ */
\ No newline at end of file
+#endif /* _HLL8ARRAY_HPP_ */
diff --git a/hll/include/HllArray-internal.hpp b/hll/include/HllArray-internal.hpp
index 1dc3e36..32dcec9 100644
--- a/hll/include/HllArray-internal.hpp
+++ b/hll/include/HllArray-internal.hpp
@@ -25,7 +25,6 @@
 #include "HarmonicNumbers.hpp"
 #include "CubicInterpolation.hpp"
 #include "CompositeInterpolationXTable.hpp"
-//#include "RelativeErrorTables.hpp"
 #include "CouponList.hpp"
 
 #include <cstring>
diff --git a/hll/include/HllArray.hpp b/hll/include/HllArray.hpp
index aa9a87e..b26872c 100644
--- a/hll/include/HllArray.hpp
+++ b/hll/include/HllArray.hpp
@@ -35,7 +35,6 @@ class HllArray : public HllSketchImpl<A> {
     explicit HllArray(int lgConfigK, TgtHllType tgtHllType, bool startFullSize);
     explicit HllArray(const HllArray<A>& that);
 
-    //static HllArray* newHll(int lgConfigK, TgtHllType tgtHllType);
     static HllArray* newHll(const void* bytes, size_t len);
     static HllArray* newHll(std::istream& is);
 
@@ -65,8 +64,6 @@ class HllArray : public HllSketchImpl<A> {
 
     virtual int getHllByteArrBytes() const = 0;
 
-    //virtual std::unique_ptr<PairIterator<A>> getIterator() const = 0;
-    //virtual std::unique_ptr<PairIterator<A>> getAuxIterator() const;
     virtual PairIterator_with_deleter<A> getIterator() const = 0;
     virtual PairIterator_with_deleter<A> getAuxIterator() const;
 
@@ -115,12 +112,9 @@ class HllArray : public HllSketchImpl<A> {
     int numAtCurMin; //interpreted as num zeros when curMin == 0
     bool oooFlag; //Out-Of-Order Flag
 
-    //friend class Conversions;
     friend class HllSketchImplFactory<A>;
 };
 
 }
 
-//#include "HllArray-internal.hpp"
-
 #endif /* _HLLARRAY_HPP_ */
diff --git a/hll/include/HllSketch-internal.hpp b/hll/include/HllSketch-internal.hpp
index 5d8296c..1661000 100644
--- a/hll/include/HllSketch-internal.hpp
+++ b/hll/include/HllSketch-internal.hpp
@@ -20,11 +20,9 @@
 #ifndef _HLLSKETCH_INTERNAL_HPP_
 #define _HLLSKETCH_INTERNAL_HPP_
 
-//#include "HllSketch.hpp"
 #include "hll.hpp"
 #include "HllUtil.hpp"
 #include "HllSketchImplFactory.hpp"
-//#include "CouponMode.hpp"
 #include "CouponList.hpp"
 #include "HllArray.hpp"
 
diff --git a/hll/include/HllSketch.hpp b/hll/include/HllSketch.hpp
deleted file mode 100644
index ec7bd26..0000000
--- a/hll/include/HllSketch.hpp
+++ /dev/null
@@ -1,122 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-#ifndef _HLLSKETCH_HPP_
-#define _HLLSKETCH_HPP_
-
-/*
-
-#include "hll.hpp"
-#include "PairIterator.hpp"
-#include "HllUtil.hpp"
-#include "HllSketchImpl.hpp"
-
-#include <memory>
-#include <iostream>
-
-namespace datasketches {
-
-class HllSketchImpl;
-
-// Contains the non-public API for HllSketch
-template<typename A = std::allocator<void>>
-class HllSketchPvt final : public HllSketch<A> {
-  public:
-    explicit HllSketchPvt(int lgConfigK, TgtHllType tgtHllType = HLL_4);
-    static HllSketchPvt<A> deserialize(std::istream& is);
-    static HllSketchPvt<A> deserialize(const void* bytes, size_t len);
-
-    virtual ~HllSketchPvt();
-
-    HllSketchPvt(const HllSketchPvt& that);
-    HllSketchPvt(HllSketchImpl* that);
-    
-    HllSketchPvt& operator=(HllSketchPvt other);
-
-    virtual HllSketchPvt<A> copy() const;
-    virtual HllSketchPvt<A> copyAs(TgtHllType tgtHllType) const;
-
-    virtual void reset();
-
-    virtual void update(const std::string& datum);
-    virtual void update(uint64_t datum);
-    virtual void update(uint32_t datum);
-    virtual void update(uint16_t datum);
-    virtual void update(uint8_t datum);
-    virtual void update(int64_t datum);
-    virtual void update(int32_t datum);
-    virtual void update(int16_t datum);
-    virtual void update(int8_t datum);
-    virtual void update(double datum);
-    virtual void update(float datum);
-    virtual void update(const void* data, size_t lengthBytes);
-    
-    virtual std::pair<std::unique_ptr<uint8_t[]>, const size_t> serializeCompact() const;
-    virtual std::pair<std::unique_ptr<uint8_t[]>, const size_t> serializeUpdatable() const;
-    virtual void serializeCompact(std::ostream& os) const;
-    virtual void serializeUpdatable(std::ostream& os) const;
-
-    virtual std::ostream& to_string(std::ostream& os,
-                                    bool summary = true,
-                                    bool detail = false,
-                                    bool auxDetail = false,
-                                    bool all = false) const;
-    virtual std::string to_string(bool summary = true,
-                                  bool detail = false,
-                                  bool auxDetail = false,
-                                  bool all = false) const;
-
-    virtual double getEstimate() const;
-    virtual double getCompositeEstimate() const;
-    virtual double getLowerBound(int numStdDev) const;
-    virtual double getUpperBound(int numStdDev) const;
-
-    virtual int getLgConfigK() const;
-    virtual TgtHllType getTgtHllType() const;
-    
-    virtual bool isCompact() const;
-    virtual bool isEmpty() const;
-
-    virtual int getUpdatableSerializationBytes() const;
-    virtual int getCompactSerializationBytes() const;
-
-    virtual std::unique_ptr<PairIterator> getIterator() const;
-
-    virtual void couponUpdate(int coupon);
-
-    virtual std::string typeAsString() const;
-    virtual std::string modeAsString() const;
-
-    CurMode getCurrentMode() const;
-    int getSerializationVersion() const;
-    bool isOutOfOrderFlag() const;
-    bool isEstimationMode() const;
-
-  private:
-    typedef typename std::allocator_traits<A>::template rebind_alloc<HllSketchPvt> AllocHllSketch;
-
-    HllSketchImpl* hllSketchImpl;
-};
-
-}
-*/
-
-//#include "HllSketch-internal.hpp"
-
-#endif // _HLLSKETCH_HPP_
diff --git a/hll/include/HllSketchImpl.hpp b/hll/include/HllSketchImpl.hpp
index 2ebf2e6..abfb4dd 100644
--- a/hll/include/HllSketchImpl.hpp
+++ b/hll/include/HllSketchImpl.hpp
@@ -36,8 +36,6 @@ class HllSketchImpl {
 
     virtual void serialize(std::ostream& os, bool compact) const = 0;
     virtual std::pair<std::unique_ptr<uint8_t, std::function<void(uint8_t*)>>, const size_t> serialize(bool compact, unsigned header_size_bytes) const = 0;
-    //static HllSketchImpl* deserialize(std::istream& os);
-    //static HllSketchImpl* deserialize(const void* bytes, size_t len);
 
     virtual HllSketchImpl* copy() const = 0;
     virtual HllSketchImpl* copyAs(TgtHllType tgtHllType) const = 0;
@@ -54,7 +52,6 @@ class HllSketchImpl {
     virtual double getUpperBound(int numStdDev) const = 0;
     virtual double getLowerBound(int numStdDev) const = 0;
 
-    //virtual std::unique_ptr<PairIterator<A>> getIterator() const = 0;
     virtual PairIterator_with_deleter<A> getIterator() const = 0;
 
     int getLgConfigK() const;
@@ -88,6 +85,4 @@ class HllSketchImpl {
 
 }
 
-//#include "HllSketchImpl-internal.hpp"
-
 #endif // _HLLSKETCHIMPL_HPP_
diff --git a/hll/include/HllSketchImplFactory.hpp b/hll/include/HllSketchImplFactory.hpp
index cb71290..5f87cdf 100644
--- a/hll/include/HllSketchImplFactory.hpp
+++ b/hll/include/HllSketchImplFactory.hpp
@@ -243,12 +243,4 @@ Hll8Array<A>* HllSketchImplFactory<A>::convertToHll8(const HllArray<A>& srcHllAr
 
 }
 
-//#include "HllSketchImpl-internal.hpp"
-//#include "CouponList-internal.hpp"
-//#include "CouponHashSet-internal.hpp"
-//#include "HllArray-internal.hpp"
-//#include "Hll4Array-internal.hpp"
-//#include "Hll6Array-internal.hpp"
-//#include "Hll8Array-internal.hpp"
-
 #endif /* _HLLSKETCHIMPLFACTORY_HPP_ */
diff --git a/hll/include/HllUnion.hpp b/hll/include/HllUnion.hpp
deleted file mode 100644
index 0adefc7..0000000
--- a/hll/include/HllUnion.hpp
+++ /dev/null
@@ -1,154 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-#ifndef _HLLUNION_HPP_
-#define _HLLUNION_HPP_
-
-#include "hll.hpp"
-#include "HllUtil.hpp"
-#include "HllSketch.hpp"
-
-//namespace datasketches {
-
-/**
- * This performs union operations for HLL sketches. This union operator is configured with a
- * <i>lgMaxK</i> instead of the normal <i>lgConfigK</i>.
- *
- * <p>This union operator does permit the unioning of sketches with different values of
- * <i>lgConfigK</i>.  The user should be aware that the resulting accuracy of a sketch returned
- * at the end of the unioning process will be a function of the smallest of <i>lgMaxK</i> and
- * <i>lgConfigK</i> that the union operator has seen.
- *
- * <p>This union operator also permits unioning of any of the three different target HllSketch
- * types.
- *
- * <p>Although the API for this union operator parallels many of the methods of the
- * <i>HllSketch</i>, the behavior of the union operator has some fundamental differences.
- *
- * <p>First, the user cannot specify the {@link TgtHllType} as an input parameter.
- * Instead, it is specified for the sketch returned with {@link #getResult(TgtHllType)}.
- *
- * <p>Second, the internal effective value of log-base-2 of <i>k</i> for the union operation can
- * change dynamically based on the smallest <i>lgConfigK</i> that the union operation has seen.
- *
- * @author Lee Rhodes
- * @author Kevin Lang
- */
-/*
-template<typename A = std::allocator<void>>
-class HllUnionPvt final : public HllUnion<A> {
-  public:
-    explicit HllUnionPvt(int lgMaxK);
-    explicit HllUnionPvt(HllSketchPvt<A>& sketch);
-
-    HllUnionPvt(const HllUnionPvt<A>& other);
-    HllUnionPvt& operator=(HllUnionPvt<A>& other);
-
-    static HllUnionPvt<A> deserialize(std::istream& is);
-    static HllUnionPvt<A> deserialize(const void* bytes, size_t len);
-
-    virtual ~HllUnionPvt();
-
-    virtual double getEstimate() const;
-    virtual double getCompositeEstimate() const;
-    virtual double getLowerBound(int numStdDev) const;
-    virtual double getUpperBound(int numStdDev) const;
-
-    virtual int getCompactSerializationBytes() const;
-    virtual int getUpdatableSerializationBytes() const;
-    virtual int getLgConfigK() const;
-
-    virtual TgtHllType getTgtHllType() const;
-    virtual bool isCompact() const;
-    virtual bool isEmpty() const;
-
-    virtual void reset();
-
-    virtual HllSketch<A> getResult(TgtHllType tgtHllType = HLL_4) const;
-
-    virtual std::pair<std::unique_ptr<uint8_t[]>, const size_t> serializeCompact() const;
-    virtual std::pair<std::unique_ptr<uint8_t[]>, const size_t> serializeUpdatable() const;
-    virtual void serializeCompact(std::ostream& os) const;
-    virtual void serializeUpdatable(std::ostream& os) const;
-
-    virtual std::ostream& to_string(std::ostream& os,
-                                    bool summary = true,
-                                    bool detail = false,
-                                    bool auxDetail = false,
-                                    bool all = false) const;
-    virtual std::string to_string(bool summary = true,
-                                  bool detail = false,
-                                  bool auxDetail = false,
-                                  bool all = false) const;                                    
-
-    virtual void update(const HllSketch<A>& sketch);
-    virtual void update(const std::string& datum);
-    virtual void update(uint64_t datum);
-    virtual void update(uint32_t datum);
-    virtual void update(uint16_t datum);
-    virtual void update(uint8_t datum);
-    virtual void update(int64_t datum);
-    virtual void update(int32_t datum);
-    virtual void update(int16_t datum);
-    virtual void update(int8_t datum);
-    virtual void update(double datum);
-    virtual void update(float datum);
-    virtual void update(const void* data, size_t lengthBytes);
-
-    void couponUpdate(int coupon);
-
-    CurMode getCurrentMode() const;
-    int getSerializationVersion() const;
-    bool isOutOfOrderFlag() const;
-    bool isEstimationMode() const;
-
-  private:
-    typedef typename std::allocator_traits<A>::template rebind_alloc<HllUnionPvt> AllocHllUnion;
-  */
-   /**
-    * Union the given source and destination sketches. This static method examines the state of
-    * the current internal gadget and the incoming sketch and determines the optimum way to
-    * perform the union. This may involve swapping, down-sampling, transforming, and / or
-    * copying one of the arguments and may completely replace the internals of the union.
-    *
-    * @param incomingImpl the given incoming sketch, which may not be modified.
-    * @param gadgetImpl the given gadget sketch, which must have a target of HLL_8 and may be
-    * modified.
-    * @param lgMaxK the maximum value of log2 K for this union.
-    * //@return the union of the two sketches in the form of the internal HllSketchImpl, which for
-    * //the union is always in HLL_8 form.
-    */
-   /*
-    void unionImpl(HllSketchImpl* incomingImpl, int lgMaxK);
-
-    static HllSketchImpl* copyOrDownsampleHll(HllSketchImpl* srcImpl, int tgtLgK);
-
-    // calls couponUpdate on sketch, freeing the old sketch upon changes in CurMode
-    static HllSketchImpl* leakFreeCouponUpdate(HllSketchImpl* impl, int coupon);
-
-    int lgMaxK;
-    HllSketchPvt<A>* gadget;
-};
-
-}
-*/
-
-//#include "HllUnion-internal.hpp"
-
-#endif // _HLLUNION_HPP_
\ No newline at end of file
diff --git a/hll/include/hll.private.hpp b/hll/include/hll.private.hpp
index 653319b..0441949 100644
--- a/hll/include/hll.private.hpp
+++ b/hll/include/hll.private.hpp
@@ -3,7 +3,6 @@
 
 #include "AuxHashMap.hpp"
 #include "CompositeInterpolationXTable.hpp"
-//#include "Conversions.hpp"
 #include "CouponHashSet.hpp"
 #include "CouponList.hpp"
 #include "CubicInterpolation.hpp"
@@ -21,7 +20,6 @@
 #include "RelativeErrorTables.hpp"
 
 #include "AuxHashMap-internal.hpp"
-//#include "Conversions-internal.hpp"
 #include "CouponHashSet-internal.hpp"
 #include "CouponList-internal.hpp"
 #include "Hll4Array-internal.hpp"


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@datasketches.apache.org
For additional commands, e-mail: commits-help@datasketches.apache.org