You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@tuweni.apache.org by to...@apache.org on 2020/06/27 08:07:55 UTC

[incubator-tuweni] branch master updated: Delete classes never used (#97)

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

toulmean pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/incubator-tuweni.git


The following commit(s) were added to refs/heads/master by this push:
     new 073beaf  Delete classes never used (#97)
073beaf is described below

commit 073beaf85c969587ff0bed88bb61d764077c59c1
Author: Antoine Toulme <at...@users.noreply.github.com>
AuthorDate: Sat Jun 27 01:07:48 2020 -0700

    Delete classes never used (#97)
---
 .../apache/tuweni/units/bigints/UInt256Domain.java | 52 -----------------
 .../tuweni/units/bigints/UInt256ValueDomain.java   | 65 ----------------------
 .../apache/tuweni/units/bigints/UInt32Domain.java  | 52 -----------------
 .../tuweni/units/bigints/UInt32ValueDomain.java    | 65 ----------------------
 .../apache/tuweni/units/bigints/UInt384Domain.java | 52 -----------------
 .../tuweni/units/bigints/UInt384ValueDomain.java   | 65 ----------------------
 .../apache/tuweni/units/bigints/UInt64Domain.java  | 52 -----------------
 .../tuweni/units/bigints/UInt64ValueDomain.java    | 65 ----------------------
 8 files changed, 468 deletions(-)

diff --git a/units/src/main/java/org/apache/tuweni/units/bigints/UInt256Domain.java b/units/src/main/java/org/apache/tuweni/units/bigints/UInt256Domain.java
deleted file mode 100644
index 8d8c188..0000000
--- a/units/src/main/java/org/apache/tuweni/units/bigints/UInt256Domain.java
+++ /dev/null
@@ -1,52 +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.
- */
-package org.apache.tuweni.units.bigints;
-
-import com.google.common.collect.DiscreteDomain;
-
-/**
- * A {@link DiscreteDomain} over {@link UInt256}.
- */
-public final class UInt256Domain extends DiscreteDomain<UInt256> {
-
-  @Override
-  public UInt256 next(UInt256 value) {
-    return value.add(1);
-  }
-
-  @Override
-  public UInt256 previous(UInt256 value) {
-    return value.subtract(1);
-  }
-
-  @Override
-  public long distance(UInt256 start, UInt256 end) {
-    boolean negativeDistance = start.compareTo(end) < 0;
-    UInt256 distance = negativeDistance ? end.subtract(start) : start.subtract(end);
-    if (!distance.fitsLong()) {
-      return negativeDistance ? Long.MIN_VALUE : Long.MAX_VALUE;
-    }
-    long distanceLong = distance.toLong();
-    return negativeDistance ? -distanceLong : distanceLong;
-  }
-
-  @Override
-  public UInt256 minValue() {
-    return UInt256.MIN_VALUE;
-  }
-
-  @Override
-  public UInt256 maxValue() {
-    return UInt256.MAX_VALUE;
-  }
-}
diff --git a/units/src/main/java/org/apache/tuweni/units/bigints/UInt256ValueDomain.java b/units/src/main/java/org/apache/tuweni/units/bigints/UInt256ValueDomain.java
deleted file mode 100644
index 79166b6..0000000
--- a/units/src/main/java/org/apache/tuweni/units/bigints/UInt256ValueDomain.java
+++ /dev/null
@@ -1,65 +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.
- */
-package org.apache.tuweni.units.bigints;
-
-import java.util.function.Function;
-
-import com.google.common.collect.DiscreteDomain;
-
-/**
- * A {@link DiscreteDomain} over a {@link UInt256Value}.
- */
-public final class UInt256ValueDomain<T extends UInt256Value<T>> extends DiscreteDomain<T> {
-
-  private final T minValue;
-  private final T maxValue;
-
-  /**
-   * @param ctor The constructor for the {@link UInt256Value} type.
-   */
-  public UInt256ValueDomain(Function<UInt256, T> ctor) {
-    this.minValue = ctor.apply(UInt256.MIN_VALUE);
-    this.maxValue = ctor.apply(UInt256.MAX_VALUE);
-  }
-
-  @Override
-  public T next(T value) {
-    return value.add(1);
-  }
-
-  @Override
-  public T previous(T value) {
-    return value.subtract(1);
-  }
-
-  @Override
-  public long distance(T start, T end) {
-    boolean negativeDistance = start.compareTo(end) < 0;
-    T distance = negativeDistance ? end.subtract(start) : start.subtract(end);
-    if (!distance.fitsLong()) {
-      return negativeDistance ? Long.MIN_VALUE : Long.MAX_VALUE;
-    }
-    long distanceLong = distance.toLong();
-    return negativeDistance ? -distanceLong : distanceLong;
-  }
-
-  @Override
-  public T minValue() {
-    return minValue;
-  }
-
-  @Override
-  public T maxValue() {
-    return maxValue;
-  }
-}
diff --git a/units/src/main/java/org/apache/tuweni/units/bigints/UInt32Domain.java b/units/src/main/java/org/apache/tuweni/units/bigints/UInt32Domain.java
deleted file mode 100644
index b339c1a..0000000
--- a/units/src/main/java/org/apache/tuweni/units/bigints/UInt32Domain.java
+++ /dev/null
@@ -1,52 +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.
- */
-package org.apache.tuweni.units.bigints;
-
-import com.google.common.collect.DiscreteDomain;
-
-/**
- * A {@link DiscreteDomain} over {@link UInt32}.
- */
-public final class UInt32Domain extends DiscreteDomain<UInt32> {
-
-  @Override
-  public UInt32 next(UInt32 value) {
-    return value.add(1);
-  }
-
-  @Override
-  public UInt32 previous(UInt32 value) {
-    return value.subtract(1);
-  }
-
-  @Override
-  public long distance(UInt32 start, UInt32 end) {
-    boolean negativeDistance = start.compareTo(end) < 0;
-    UInt32 distance = negativeDistance ? end.subtract(start) : start.subtract(end);
-    if (!distance.fitsLong()) {
-      return negativeDistance ? Long.MIN_VALUE : Long.MAX_VALUE;
-    }
-    long distanceLong = distance.toLong();
-    return negativeDistance ? -distanceLong : distanceLong;
-  }
-
-  @Override
-  public UInt32 minValue() {
-    return UInt32.MIN_VALUE;
-  }
-
-  @Override
-  public UInt32 maxValue() {
-    return UInt32.MAX_VALUE;
-  }
-}
diff --git a/units/src/main/java/org/apache/tuweni/units/bigints/UInt32ValueDomain.java b/units/src/main/java/org/apache/tuweni/units/bigints/UInt32ValueDomain.java
deleted file mode 100644
index 06a43e1..0000000
--- a/units/src/main/java/org/apache/tuweni/units/bigints/UInt32ValueDomain.java
+++ /dev/null
@@ -1,65 +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.
- */
-package org.apache.tuweni.units.bigints;
-
-import java.util.function.Function;
-
-import com.google.common.collect.DiscreteDomain;
-
-/**
- * A {@link DiscreteDomain} over a {@link UInt32Value}.
- */
-public final class UInt32ValueDomain<T extends UInt32Value<T>> extends DiscreteDomain<T> {
-
-  private final T minValue;
-  private final T maxValue;
-
-  /**
-   * @param ctor The constructor for the {@link UInt32Value} type.
-   */
-  public UInt32ValueDomain(Function<UInt32, T> ctor) {
-    this.minValue = ctor.apply(UInt32.MIN_VALUE);
-    this.maxValue = ctor.apply(UInt32.MAX_VALUE);
-  }
-
-  @Override
-  public T next(T value) {
-    return value.add(1);
-  }
-
-  @Override
-  public T previous(T value) {
-    return value.subtract(1);
-  }
-
-  @Override
-  public long distance(T start, T end) {
-    boolean negativeDistance = start.compareTo(end) < 0;
-    T distance = negativeDistance ? end.subtract(start) : start.subtract(end);
-    if (!distance.fitsLong()) {
-      return negativeDistance ? Long.MIN_VALUE : Long.MAX_VALUE;
-    }
-    long distanceLong = distance.toLong();
-    return negativeDistance ? -distanceLong : distanceLong;
-  }
-
-  @Override
-  public T minValue() {
-    return minValue;
-  }
-
-  @Override
-  public T maxValue() {
-    return maxValue;
-  }
-}
diff --git a/units/src/main/java/org/apache/tuweni/units/bigints/UInt384Domain.java b/units/src/main/java/org/apache/tuweni/units/bigints/UInt384Domain.java
deleted file mode 100644
index fe08115..0000000
--- a/units/src/main/java/org/apache/tuweni/units/bigints/UInt384Domain.java
+++ /dev/null
@@ -1,52 +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.
- */
-package org.apache.tuweni.units.bigints;
-
-import com.google.common.collect.DiscreteDomain;
-
-/**
- * A {@link DiscreteDomain} over {@link UInt384}.
- */
-public final class UInt384Domain extends DiscreteDomain<UInt384> {
-
-  @Override
-  public UInt384 next(UInt384 value) {
-    return value.add(1);
-  }
-
-  @Override
-  public UInt384 previous(UInt384 value) {
-    return value.subtract(1);
-  }
-
-  @Override
-  public long distance(UInt384 start, UInt384 end) {
-    boolean negativeDistance = start.compareTo(end) < 0;
-    UInt384 distance = negativeDistance ? end.subtract(start) : start.subtract(end);
-    if (!distance.fitsLong()) {
-      return negativeDistance ? Long.MIN_VALUE : Long.MAX_VALUE;
-    }
-    long distanceLong = distance.toLong();
-    return negativeDistance ? -distanceLong : distanceLong;
-  }
-
-  @Override
-  public UInt384 minValue() {
-    return UInt384.MIN_VALUE;
-  }
-
-  @Override
-  public UInt384 maxValue() {
-    return UInt384.MAX_VALUE;
-  }
-}
diff --git a/units/src/main/java/org/apache/tuweni/units/bigints/UInt384ValueDomain.java b/units/src/main/java/org/apache/tuweni/units/bigints/UInt384ValueDomain.java
deleted file mode 100644
index ae3d5d7..0000000
--- a/units/src/main/java/org/apache/tuweni/units/bigints/UInt384ValueDomain.java
+++ /dev/null
@@ -1,65 +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.
- */
-package org.apache.tuweni.units.bigints;
-
-import java.util.function.Function;
-
-import com.google.common.collect.DiscreteDomain;
-
-/**
- * A {@link DiscreteDomain} over a {@link UInt384Value}.
- */
-public final class UInt384ValueDomain<T extends UInt384Value<T>> extends DiscreteDomain<T> {
-
-  private final T minValue;
-  private final T maxValue;
-
-  /**
-   * @param ctor The constructor for the {@link UInt384Value} type.
-   */
-  public UInt384ValueDomain(Function<UInt384, T> ctor) {
-    this.minValue = ctor.apply(UInt384.MIN_VALUE);
-    this.maxValue = ctor.apply(UInt384.MAX_VALUE);
-  }
-
-  @Override
-  public T next(T value) {
-    return value.add(1);
-  }
-
-  @Override
-  public T previous(T value) {
-    return value.subtract(1);
-  }
-
-  @Override
-  public long distance(T start, T end) {
-    boolean negativeDistance = start.compareTo(end) < 0;
-    T distance = negativeDistance ? end.subtract(start) : start.subtract(end);
-    if (!distance.fitsLong()) {
-      return negativeDistance ? Long.MIN_VALUE : Long.MAX_VALUE;
-    }
-    long distanceLong = distance.toLong();
-    return negativeDistance ? -distanceLong : distanceLong;
-  }
-
-  @Override
-  public T minValue() {
-    return minValue;
-  }
-
-  @Override
-  public T maxValue() {
-    return maxValue;
-  }
-}
diff --git a/units/src/main/java/org/apache/tuweni/units/bigints/UInt64Domain.java b/units/src/main/java/org/apache/tuweni/units/bigints/UInt64Domain.java
deleted file mode 100644
index ccdeb69..0000000
--- a/units/src/main/java/org/apache/tuweni/units/bigints/UInt64Domain.java
+++ /dev/null
@@ -1,52 +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.
- */
-package org.apache.tuweni.units.bigints;
-
-import com.google.common.collect.DiscreteDomain;
-
-/**
- * A {@link DiscreteDomain} over {@link UInt64}.
- */
-public final class UInt64Domain extends DiscreteDomain<UInt64> {
-
-  @Override
-  public UInt64 next(UInt64 value) {
-    return value.add(1);
-  }
-
-  @Override
-  public UInt64 previous(UInt64 value) {
-    return value.subtract(1);
-  }
-
-  @Override
-  public long distance(UInt64 start, UInt64 end) {
-    boolean negativeDistance = start.compareTo(end) < 0;
-    UInt64 distance = negativeDistance ? end.subtract(start) : start.subtract(end);
-    if (!distance.fitsLong()) {
-      return negativeDistance ? Long.MIN_VALUE : Long.MAX_VALUE;
-    }
-    long distanceLong = distance.toLong();
-    return negativeDistance ? -distanceLong : distanceLong;
-  }
-
-  @Override
-  public UInt64 minValue() {
-    return UInt64.MIN_VALUE;
-  }
-
-  @Override
-  public UInt64 maxValue() {
-    return UInt64.MAX_VALUE;
-  }
-}
diff --git a/units/src/main/java/org/apache/tuweni/units/bigints/UInt64ValueDomain.java b/units/src/main/java/org/apache/tuweni/units/bigints/UInt64ValueDomain.java
deleted file mode 100644
index c0ede0a..0000000
--- a/units/src/main/java/org/apache/tuweni/units/bigints/UInt64ValueDomain.java
+++ /dev/null
@@ -1,65 +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.
- */
-package org.apache.tuweni.units.bigints;
-
-import java.util.function.Function;
-
-import com.google.common.collect.DiscreteDomain;
-
-/**
- * A {@link DiscreteDomain} over a {@link UInt64Value}.
- */
-public final class UInt64ValueDomain<T extends UInt64Value<T>> extends DiscreteDomain<T> {
-
-  private final T minValue;
-  private final T maxValue;
-
-  /**
-   * @param ctor The constructor for the {@link UInt64Value} type.
-   */
-  public UInt64ValueDomain(Function<UInt64, T> ctor) {
-    this.minValue = ctor.apply(UInt64.MIN_VALUE);
-    this.maxValue = ctor.apply(UInt64.MAX_VALUE);
-  }
-
-  @Override
-  public T next(T value) {
-    return value.add(1);
-  }
-
-  @Override
-  public T previous(T value) {
-    return value.subtract(1);
-  }
-
-  @Override
-  public long distance(T start, T end) {
-    boolean negativeDistance = start.compareTo(end) < 0;
-    T distance = negativeDistance ? end.subtract(start) : start.subtract(end);
-    if (!distance.fitsLong()) {
-      return negativeDistance ? Long.MIN_VALUE : Long.MAX_VALUE;
-    }
-    long distanceLong = distance.toLong();
-    return negativeDistance ? -distanceLong : distanceLong;
-  }
-
-  @Override
-  public T minValue() {
-    return minValue;
-  }
-
-  @Override
-  public T maxValue() {
-    return maxValue;
-  }
-}


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