You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@lucene.apache.org by da...@apache.org on 2018/11/02 11:16:49 UTC

[40/56] lucene-solr:jira/gradle: Add :solr:contrib:analytics module

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f0366b94/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/BooleanArrayReservation.java
----------------------------------------------------------------------
diff --git a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/BooleanArrayReservation.java b/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/BooleanArrayReservation.java
deleted file mode 100644
index b0ca38d..0000000
--- a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/BooleanArrayReservation.java
+++ /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.
- */
-package org.apache.solr.analytics.stream.reservation;
-
-import java.io.DataInput;
-import java.io.DataOutput;
-import java.util.function.BooleanSupplier;
-import java.util.function.IntConsumer;
-import java.util.function.IntSupplier;
-
-import org.apache.solr.analytics.stream.reservation.read.BooleanDataArrayReader;
-import org.apache.solr.analytics.stream.reservation.write.BooleanDataArrayWriter;
-import org.apache.solr.analytics.util.function.BooleanConsumer;
-
-public class BooleanArrayReservation extends ReductionDataArrayReservation<BooleanConsumer, BooleanSupplier> {
-  
-  public BooleanArrayReservation(BooleanConsumer applier, IntConsumer sizeApplier, BooleanSupplier extractor, IntSupplier sizeExtractor) {
-    super(applier, sizeApplier, extractor, sizeExtractor);
-  }
-
-  @Override
-  public BooleanDataArrayReader createReadStream(DataInput input) {
-    return new BooleanDataArrayReader(input, applier, sizeApplier);
-  }
-
-  @Override
-  public BooleanDataArrayWriter createWriteStream(DataOutput output) {
-    return new BooleanDataArrayWriter(output, extractor, sizeExtractor);
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f0366b94/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/BooleanCheckedReservation.java
----------------------------------------------------------------------
diff --git a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/BooleanCheckedReservation.java b/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/BooleanCheckedReservation.java
deleted file mode 100644
index 1c3d9ec..0000000
--- a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/BooleanCheckedReservation.java
+++ /dev/null
@@ -1,42 +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.solr.analytics.stream.reservation;
-
-import java.io.DataInput;
-import java.io.DataOutput;
-import java.util.function.BooleanSupplier;
-
-import org.apache.solr.analytics.stream.reservation.read.BooleanCheckedDataReader;
-import org.apache.solr.analytics.stream.reservation.write.BooleanCheckedDataWriter;
-import org.apache.solr.analytics.util.function.BooleanConsumer;
-
-public class BooleanCheckedReservation extends ReductionCheckedDataReservation<BooleanConsumer, BooleanSupplier> {
-  
-  public BooleanCheckedReservation(BooleanConsumer applier, BooleanSupplier extractor, BooleanSupplier exists) {
-    super(applier, extractor, exists);
-  }
-
-  @Override
-  public BooleanCheckedDataReader createReadStream(DataInput input) {
-    return new BooleanCheckedDataReader(input, applier);
-  }
-
-  @Override
-  public BooleanCheckedDataWriter createWriteStream(DataOutput output) {
-    return new BooleanCheckedDataWriter(output, extractor, exists);
-  }
-}

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f0366b94/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/BooleanReservation.java
----------------------------------------------------------------------
diff --git a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/BooleanReservation.java b/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/BooleanReservation.java
deleted file mode 100644
index 2e6b718..0000000
--- a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/BooleanReservation.java
+++ /dev/null
@@ -1,42 +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.solr.analytics.stream.reservation;
-
-import java.io.DataInput;
-import java.io.DataOutput;
-import java.util.function.BooleanSupplier;
-
-import org.apache.solr.analytics.stream.reservation.read.BooleanDataReader;
-import org.apache.solr.analytics.stream.reservation.write.BooleanDataWriter;
-import org.apache.solr.analytics.util.function.BooleanConsumer;
-
-public class BooleanReservation extends ReductionDataReservation<BooleanConsumer, BooleanSupplier> {
-  
-  public BooleanReservation(BooleanConsumer applier, BooleanSupplier extractor) {
-    super(applier, extractor);
-  }
-
-  @Override
-  public BooleanDataReader createReadStream(DataInput input) {
-    return new BooleanDataReader(input, applier);
-  }
-
-  @Override
-  public BooleanDataWriter createWriteStream(DataOutput output) {
-    return new BooleanDataWriter(output, extractor);
-  }
-}

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f0366b94/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/DoubleArrayReservation.java
----------------------------------------------------------------------
diff --git a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/DoubleArrayReservation.java b/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/DoubleArrayReservation.java
deleted file mode 100644
index 6acf657..0000000
--- a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/DoubleArrayReservation.java
+++ /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.
- */
-package org.apache.solr.analytics.stream.reservation;
-
-import java.io.DataInput;
-import java.io.DataOutput;
-import java.util.function.DoubleConsumer;
-import java.util.function.DoubleSupplier;
-import java.util.function.IntConsumer;
-import java.util.function.IntSupplier;
-
-import org.apache.solr.analytics.stream.reservation.read.DoubleDataArrayReader;
-import org.apache.solr.analytics.stream.reservation.write.DoubleDataArrayWriter;
-
-public class DoubleArrayReservation extends ReductionDataArrayReservation<DoubleConsumer, DoubleSupplier> {
-  
-  public DoubleArrayReservation(DoubleConsumer applier, IntConsumer sizeApplier, DoubleSupplier extractor, IntSupplier sizeExtractor) {
-    super(applier, sizeApplier, extractor, sizeExtractor);
-  }
-
-  @Override
-  public DoubleDataArrayReader createReadStream(DataInput input) {
-    return new DoubleDataArrayReader(input, applier, sizeApplier);
-  }
-
-  @Override
-  public DoubleDataArrayWriter createWriteStream(DataOutput output) {
-    return new DoubleDataArrayWriter(output, extractor, sizeExtractor);
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f0366b94/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/DoubleCheckedReservation.java
----------------------------------------------------------------------
diff --git a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/DoubleCheckedReservation.java b/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/DoubleCheckedReservation.java
deleted file mode 100644
index a1dd461..0000000
--- a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/DoubleCheckedReservation.java
+++ /dev/null
@@ -1,43 +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.solr.analytics.stream.reservation;
-
-import java.io.DataInput;
-import java.io.DataOutput;
-import java.util.function.BooleanSupplier;
-import java.util.function.DoubleConsumer;
-import java.util.function.DoubleSupplier;
-
-import org.apache.solr.analytics.stream.reservation.read.DoubleCheckedDataReader;
-import org.apache.solr.analytics.stream.reservation.write.DoubleCheckedDataWriter;
-
-public class DoubleCheckedReservation extends ReductionCheckedDataReservation<DoubleConsumer, DoubleSupplier> {
-  
-  public DoubleCheckedReservation(DoubleConsumer applier, DoubleSupplier extractor, BooleanSupplier exists) {
-    super(applier, extractor, exists);
-  }
-
-  @Override
-  public DoubleCheckedDataReader createReadStream(DataInput input) {
-    return new DoubleCheckedDataReader(input, applier);
-  }
-
-  @Override
-  public DoubleCheckedDataWriter createWriteStream(DataOutput output) {
-    return new DoubleCheckedDataWriter(output, extractor, exists);
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f0366b94/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/DoubleReservation.java
----------------------------------------------------------------------
diff --git a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/DoubleReservation.java b/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/DoubleReservation.java
deleted file mode 100644
index 8ef3bef..0000000
--- a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/DoubleReservation.java
+++ /dev/null
@@ -1,42 +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.solr.analytics.stream.reservation;
-
-import java.io.DataInput;
-import java.io.DataOutput;
-import java.util.function.DoubleConsumer;
-import java.util.function.DoubleSupplier;
-
-import org.apache.solr.analytics.stream.reservation.read.DoubleDataReader;
-import org.apache.solr.analytics.stream.reservation.write.DoubleDataWriter;
-
-public class DoubleReservation extends ReductionDataReservation<DoubleConsumer, DoubleSupplier> {
-  
-  public DoubleReservation(DoubleConsumer applier, DoubleSupplier extractor) {
-    super(applier, extractor);
-  }
-
-  @Override
-  public DoubleDataReader createReadStream(DataInput input) {
-    return new DoubleDataReader(input, applier);
-  }
-
-  @Override
-  public DoubleDataWriter createWriteStream(DataOutput output) {
-    return new DoubleDataWriter(output, extractor);
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f0366b94/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/FloatArrayReservation.java
----------------------------------------------------------------------
diff --git a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/FloatArrayReservation.java b/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/FloatArrayReservation.java
deleted file mode 100644
index 702106d..0000000
--- a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/FloatArrayReservation.java
+++ /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.
- */
-package org.apache.solr.analytics.stream.reservation;
-
-import java.io.DataInput;
-import java.io.DataOutput;
-import java.util.function.IntConsumer;
-import java.util.function.IntSupplier;
-
-import org.apache.solr.analytics.stream.reservation.read.FloatDataArrayReader;
-import org.apache.solr.analytics.stream.reservation.write.FloatDataArrayWriter;
-import org.apache.solr.analytics.util.function.FloatConsumer;
-import org.apache.solr.analytics.util.function.FloatSupplier;
-
-public class FloatArrayReservation extends ReductionDataArrayReservation<FloatConsumer, FloatSupplier> {
-  
-  public FloatArrayReservation(FloatConsumer applier, IntConsumer sizeApplier, FloatSupplier extractor, IntSupplier sizeExtractor) {
-    super(applier, sizeApplier, extractor, sizeExtractor);
-  }
-
-  @Override
-  public FloatDataArrayReader createReadStream(DataInput input) {
-    return new FloatDataArrayReader(input, applier, sizeApplier);
-  }
-
-  @Override
-  public FloatDataArrayWriter createWriteStream(DataOutput output) {
-    return new FloatDataArrayWriter(output, extractor, sizeExtractor);
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f0366b94/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/FloatCheckedReservation.java
----------------------------------------------------------------------
diff --git a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/FloatCheckedReservation.java b/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/FloatCheckedReservation.java
deleted file mode 100644
index 581772c..0000000
--- a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/FloatCheckedReservation.java
+++ /dev/null
@@ -1,43 +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.solr.analytics.stream.reservation;
-
-import java.io.DataInput;
-import java.io.DataOutput;
-import java.util.function.BooleanSupplier;
-
-import org.apache.solr.analytics.stream.reservation.read.FloatCheckedDataReader;
-import org.apache.solr.analytics.stream.reservation.write.FloatCheckedDataWriter;
-import org.apache.solr.analytics.util.function.FloatConsumer;
-import org.apache.solr.analytics.util.function.FloatSupplier;
-
-public class FloatCheckedReservation extends ReductionCheckedDataReservation<FloatConsumer, FloatSupplier> {
-  
-  public FloatCheckedReservation(FloatConsumer applier, FloatSupplier extractor, BooleanSupplier exists) {
-    super(applier, extractor, exists);
-  }
-
-  @Override
-  public FloatCheckedDataReader createReadStream(DataInput input) {
-    return new FloatCheckedDataReader(input, applier);
-  }
-
-  @Override
-  public FloatCheckedDataWriter createWriteStream(DataOutput output) {
-    return new FloatCheckedDataWriter(output, extractor, exists);
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f0366b94/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/FloatReservation.java
----------------------------------------------------------------------
diff --git a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/FloatReservation.java b/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/FloatReservation.java
deleted file mode 100644
index c0ea5f0..0000000
--- a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/FloatReservation.java
+++ /dev/null
@@ -1,42 +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.solr.analytics.stream.reservation;
-
-import java.io.DataInput;
-import java.io.DataOutput;
-
-import org.apache.solr.analytics.stream.reservation.read.FloatDataReader;
-import org.apache.solr.analytics.stream.reservation.write.FloatDataWriter;
-import org.apache.solr.analytics.util.function.FloatConsumer;
-import org.apache.solr.analytics.util.function.FloatSupplier;
-
-public class FloatReservation extends ReductionDataReservation<FloatConsumer, FloatSupplier> {
-  
-  public FloatReservation(FloatConsumer applier, FloatSupplier extractor) {
-    super(applier, extractor);
-  }
-
-  @Override
-  public FloatDataReader createReadStream(DataInput input) {
-    return new FloatDataReader(input, applier);
-  }
-
-  @Override
-  public FloatDataWriter createWriteStream(DataOutput output) {
-    return new FloatDataWriter(output, extractor);
-  }
-}

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f0366b94/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/IntArrayReservation.java
----------------------------------------------------------------------
diff --git a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/IntArrayReservation.java b/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/IntArrayReservation.java
deleted file mode 100644
index e3639a1..0000000
--- a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/IntArrayReservation.java
+++ /dev/null
@@ -1,42 +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.solr.analytics.stream.reservation;
-
-import java.io.DataInput;
-import java.io.DataOutput;
-import java.util.function.IntConsumer;
-import java.util.function.IntSupplier;
-
-import org.apache.solr.analytics.stream.reservation.read.IntDataArrayReader;
-import org.apache.solr.analytics.stream.reservation.write.IntDataArrayWriter;
-
-public class IntArrayReservation extends ReductionDataArrayReservation<IntConsumer, IntSupplier> {
-  
-  public IntArrayReservation(IntConsumer applier, IntConsumer sizeApplier, IntSupplier extractor, IntSupplier sizeExtractor) {
-    super(applier, sizeApplier, extractor, sizeExtractor);
-  }
-
-  @Override
-  public IntDataArrayReader createReadStream(DataInput input) {
-    return new IntDataArrayReader(input, applier, sizeApplier);
-  }
-
-  @Override
-  public IntDataArrayWriter createWriteStream(DataOutput output) {
-    return new IntDataArrayWriter(output, extractor, sizeExtractor);
-  }
-}

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f0366b94/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/IntCheckedReservation.java
----------------------------------------------------------------------
diff --git a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/IntCheckedReservation.java b/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/IntCheckedReservation.java
deleted file mode 100644
index c0a7cf2..0000000
--- a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/IntCheckedReservation.java
+++ /dev/null
@@ -1,43 +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.solr.analytics.stream.reservation;
-
-import java.io.DataInput;
-import java.io.DataOutput;
-import java.util.function.BooleanSupplier;
-import java.util.function.IntConsumer;
-import java.util.function.IntSupplier;
-
-import org.apache.solr.analytics.stream.reservation.read.IntCheckedDataReader;
-import org.apache.solr.analytics.stream.reservation.write.IntCheckedDataWriter;
-
-public class IntCheckedReservation extends ReductionCheckedDataReservation<IntConsumer, IntSupplier> {
-  
-  public IntCheckedReservation(IntConsumer applier, IntSupplier extractor, BooleanSupplier exists) {
-    super(applier, extractor, exists);
-  }
-
-  @Override
-  public IntCheckedDataReader createReadStream(DataInput input) {
-    return new IntCheckedDataReader(input, applier);
-  }
-
-  @Override
-  public IntCheckedDataWriter createWriteStream(DataOutput output) {
-    return new IntCheckedDataWriter(output, extractor, exists);
-  }
-}

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f0366b94/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/IntReservation.java
----------------------------------------------------------------------
diff --git a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/IntReservation.java b/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/IntReservation.java
deleted file mode 100644
index cb66b58..0000000
--- a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/IntReservation.java
+++ /dev/null
@@ -1,42 +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.solr.analytics.stream.reservation;
-
-import java.io.DataInput;
-import java.io.DataOutput;
-import java.util.function.IntConsumer;
-import java.util.function.IntSupplier;
-
-import org.apache.solr.analytics.stream.reservation.read.IntDataReader;
-import org.apache.solr.analytics.stream.reservation.write.IntDataWriter;
-
-public class IntReservation extends ReductionDataReservation<IntConsumer, IntSupplier> {
-  
-  public IntReservation(IntConsumer applier, IntSupplier extractor) {
-    super(applier, extractor);
-  }
-
-  @Override
-  public IntDataReader createReadStream(DataInput input) {
-    return new IntDataReader(input, applier);
-  }
-
-  @Override
-  public IntDataWriter createWriteStream(DataOutput output) {
-    return new IntDataWriter(output, extractor);
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f0366b94/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/LongArrayReservation.java
----------------------------------------------------------------------
diff --git a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/LongArrayReservation.java b/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/LongArrayReservation.java
deleted file mode 100644
index 980bc2b..0000000
--- a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/LongArrayReservation.java
+++ /dev/null
@@ -1,45 +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.solr.analytics.stream.reservation;
-
-import java.io.DataInput;
-import java.io.DataOutput;
-import java.util.function.LongConsumer;
-import java.util.function.LongSupplier;
-
-import org.apache.solr.analytics.stream.reservation.read.LongDataArrayReader;
-import org.apache.solr.analytics.stream.reservation.write.LongDataArrayWriter;
-
-import java.util.function.IntConsumer;
-import java.util.function.IntSupplier;
-
-public class LongArrayReservation extends ReductionDataArrayReservation<LongConsumer, LongSupplier> {
-  
-  public LongArrayReservation(LongConsumer applier, IntConsumer sizeApplier, LongSupplier extractor, IntSupplier sizeExtractor) {
-    super(applier, sizeApplier, extractor, sizeExtractor);
-  }
-
-  @Override
-  public LongDataArrayReader createReadStream(DataInput input) {
-    return new LongDataArrayReader(input, applier, sizeApplier);
-  }
-
-  @Override
-  public LongDataArrayWriter createWriteStream(DataOutput output) {
-    return new LongDataArrayWriter(output, extractor, sizeExtractor);
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f0366b94/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/LongCheckedReservation.java
----------------------------------------------------------------------
diff --git a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/LongCheckedReservation.java b/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/LongCheckedReservation.java
deleted file mode 100644
index e1626e5..0000000
--- a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/LongCheckedReservation.java
+++ /dev/null
@@ -1,43 +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.solr.analytics.stream.reservation;
-
-import java.io.DataInput;
-import java.io.DataOutput;
-import java.util.function.BooleanSupplier;
-import java.util.function.LongConsumer;
-import java.util.function.LongSupplier;
-
-import org.apache.solr.analytics.stream.reservation.read.LongCheckedDataReader;
-import org.apache.solr.analytics.stream.reservation.write.LongCheckedDataWriter;
-
-public class LongCheckedReservation extends ReductionCheckedDataReservation<LongConsumer, LongSupplier> {
-  
-  public LongCheckedReservation(LongConsumer applier, LongSupplier extractor, BooleanSupplier exists) {
-    super(applier, extractor, exists);
-  }
-
-  @Override
-  public LongCheckedDataReader createReadStream(DataInput input) {
-    return new LongCheckedDataReader(input, applier);
-  }
-
-  @Override
-  public LongCheckedDataWriter createWriteStream(DataOutput output) {
-    return new LongCheckedDataWriter(output, extractor, exists);
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f0366b94/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/LongReservation.java
----------------------------------------------------------------------
diff --git a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/LongReservation.java b/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/LongReservation.java
deleted file mode 100644
index daf8ec3..0000000
--- a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/LongReservation.java
+++ /dev/null
@@ -1,42 +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.solr.analytics.stream.reservation;
-
-import java.io.DataInput;
-import java.io.DataOutput;
-import java.util.function.LongConsumer;
-import java.util.function.LongSupplier;
-
-import org.apache.solr.analytics.stream.reservation.read.LongDataReader;
-import org.apache.solr.analytics.stream.reservation.write.LongDataWriter;
-
-public class LongReservation extends ReductionDataReservation<LongConsumer, LongSupplier> {
-  
-  public LongReservation(LongConsumer applier, LongSupplier extractor) {
-    super(applier, extractor);
-  }
-
-  @Override
-  public LongDataReader createReadStream(DataInput input) {
-    return new LongDataReader(input, applier);
-  }
-
-  @Override
-  public LongDataWriter createWriteStream(DataOutput output) {
-    return new LongDataWriter(output, extractor);
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f0366b94/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/ReductionCheckedDataReservation.java
----------------------------------------------------------------------
diff --git a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/ReductionCheckedDataReservation.java b/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/ReductionCheckedDataReservation.java
deleted file mode 100644
index 73287fe..0000000
--- a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/ReductionCheckedDataReservation.java
+++ /dev/null
@@ -1,35 +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.solr.analytics.stream.reservation;
-
-import java.util.function.BooleanSupplier;
-
-import org.apache.solr.analytics.function.reduction.data.ReductionDataCollector;
-
-/**
- * A reservation allows a {@link ReductionDataCollector} to specify a piece of data it needs to export from the shard.
- * This data may, or may not, exist. The {@link ReductionDataCollector} need not check while importing/exporting since
- * the Reader/Writers handle all checking.
- */
-public abstract class ReductionCheckedDataReservation<A, E> extends ReductionDataReservation<A, E> {
-  protected final BooleanSupplier exists;
-  
-  protected ReductionCheckedDataReservation(A applier, E extractor, BooleanSupplier exists) {
-    super(applier, extractor);
-    this.exists = exists;
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f0366b94/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/ReductionDataArrayReservation.java
----------------------------------------------------------------------
diff --git a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/ReductionDataArrayReservation.java b/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/ReductionDataArrayReservation.java
deleted file mode 100644
index cbeece6..0000000
--- a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/ReductionDataArrayReservation.java
+++ /dev/null
@@ -1,36 +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.solr.analytics.stream.reservation;
-
-import java.util.function.IntConsumer;
-import java.util.function.IntSupplier;
-
-import org.apache.solr.analytics.function.reduction.data.ReductionDataCollector;
-
-/**
- * A reservation allows a {@link ReductionDataCollector} to specify an array of data it needs to export from the shard.
- */
-public abstract class ReductionDataArrayReservation<A, E> extends ReductionDataReservation<A, E> {
-  protected final IntConsumer sizeApplier;
-  protected final IntSupplier sizeExtractor;
-  
-  protected ReductionDataArrayReservation(A applier, IntConsumer sizeApplier, E extractor, IntSupplier sizeExtractor) {
-    super(applier, extractor);
-    this.sizeApplier = sizeApplier;
-    this.sizeExtractor = sizeExtractor;
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f0366b94/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/ReductionDataReservation.java
----------------------------------------------------------------------
diff --git a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/ReductionDataReservation.java b/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/ReductionDataReservation.java
deleted file mode 100644
index 903016e..0000000
--- a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/ReductionDataReservation.java
+++ /dev/null
@@ -1,53 +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.solr.analytics.stream.reservation;
-
-import java.io.DataInput;
-import java.io.DataOutput;
-
-import org.apache.solr.analytics.function.reduction.data.ReductionDataCollector;
-import org.apache.solr.analytics.stream.reservation.read.ReductionDataReader;
-import org.apache.solr.analytics.stream.reservation.write.ReductionDataWriter;
-
-/**
- * A reservation allows a {@link ReductionDataCollector} to specify a piece of data it needs to export from the shard.
- */
-public abstract class ReductionDataReservation<A, E> {
-  protected final A applier;
-  protected final E extractor;
-  
-  protected ReductionDataReservation(A applier, E extractor) {
-    this.applier = applier;
-    this.extractor = extractor;
-  }
-  
-  /**
-   * Generate a {@link ReductionDataReader} that merges the set of data this reservation represents.
-   * 
-   * @param input the shard input stream
-   * @return a reader from the given input
-   */
-  public abstract ReductionDataReader<A> createReadStream(DataInput input);
-  
-  /**
-   * Generate a {@link ReductionDataWriter} that exports the set of data this reservation represents.
-   * 
-   * @param output the shard output stream
-   * @return a writer to the given output
-   */
-  public abstract ReductionDataWriter<E> createWriteStream(DataOutput output);
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f0366b94/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/StringArrayReservation.java
----------------------------------------------------------------------
diff --git a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/StringArrayReservation.java b/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/StringArrayReservation.java
deleted file mode 100644
index c3c6989..0000000
--- a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/StringArrayReservation.java
+++ /dev/null
@@ -1,45 +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.solr.analytics.stream.reservation;
-
-import java.io.DataInput;
-import java.io.DataOutput;
-import java.util.function.Consumer;
-import java.util.function.Supplier;
-
-import org.apache.solr.analytics.stream.reservation.read.StringDataArrayReader;
-import org.apache.solr.analytics.stream.reservation.write.StringDataArrayWriter;
-
-import java.util.function.IntConsumer;
-import java.util.function.IntSupplier;
-
-public class StringArrayReservation extends ReductionDataArrayReservation<Consumer<String>, Supplier<String>> {
-  
-  public StringArrayReservation(Consumer<String> applier, IntConsumer sizeApplier, Supplier<String> extractor, IntSupplier sizeExtractor) {
-    super(applier, sizeApplier, extractor, sizeExtractor);
-  }
-
-  @Override
-  public StringDataArrayReader createReadStream(DataInput input) {
-    return new StringDataArrayReader(input, applier, sizeApplier);
-  }
-
-  @Override
-  public StringDataArrayWriter createWriteStream(DataOutput output) {
-    return new StringDataArrayWriter(output, extractor, sizeExtractor);
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f0366b94/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/StringCheckedReservation.java
----------------------------------------------------------------------
diff --git a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/StringCheckedReservation.java b/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/StringCheckedReservation.java
deleted file mode 100644
index 29c3614..0000000
--- a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/StringCheckedReservation.java
+++ /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.
- */
-package org.apache.solr.analytics.stream.reservation;
-
-import java.io.DataInput;
-import java.io.DataOutput;
-import java.util.function.Supplier;
-
-import org.apache.solr.analytics.stream.reservation.read.StringCheckedDataReader;
-import org.apache.solr.analytics.stream.reservation.write.StringCheckedDataWriter;
-
-import java.util.function.BooleanSupplier;
-import java.util.function.Consumer;
-
-public class StringCheckedReservation extends ReductionCheckedDataReservation<Consumer<String>, Supplier<String>> {
-  
-  public StringCheckedReservation(Consumer<String> applier, Supplier<String> extractor, BooleanSupplier exists) {
-    super(applier, extractor, exists);
-  }
-
-  @Override
-  public StringCheckedDataReader createReadStream(DataInput input) {
-    return new StringCheckedDataReader(input, applier);
-  }
-
-  @Override
-  public StringCheckedDataWriter createWriteStream(DataOutput output) {
-    return new StringCheckedDataWriter(output, extractor, exists);
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f0366b94/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/StringReservation.java
----------------------------------------------------------------------
diff --git a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/StringReservation.java b/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/StringReservation.java
deleted file mode 100644
index 2601874..0000000
--- a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/StringReservation.java
+++ /dev/null
@@ -1,43 +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.solr.analytics.stream.reservation;
-
-import java.io.DataInput;
-import java.io.DataOutput;
-import java.util.function.Supplier;
-
-import org.apache.solr.analytics.stream.reservation.read.StringDataReader;
-import org.apache.solr.analytics.stream.reservation.write.StringDataWriter;
-
-import java.util.function.Consumer;
-
-public class StringReservation extends ReductionDataReservation<Consumer<String>, Supplier<String>> {
-  
-  public StringReservation(Consumer<String> applier, Supplier<String> extractor) {
-    super(applier, extractor);
-  }
-
-  @Override
-  public StringDataReader createReadStream(DataInput input) {
-    return new StringDataReader(input, applier);
-  }
-
-  @Override
-  public StringDataWriter createWriteStream(DataOutput output) {
-    return new StringDataWriter(output, extractor);
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f0366b94/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/package-info.java
----------------------------------------------------------------------
diff --git a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/package-info.java b/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/package-info.java
deleted file mode 100644
index bfd832d..0000000
--- a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/package-info.java
+++ /dev/null
@@ -1,24 +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.
- */
- 
-/** 
- * Reservation classes for a single type of data being stored by one Reduction Data Collector.
- * These reservations are imported/exported between shards during the streaming process.
- */
-package org.apache.solr.analytics.stream.reservation;
-
-

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f0366b94/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/BooleanCheckedDataReader.java
----------------------------------------------------------------------
diff --git a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/BooleanCheckedDataReader.java b/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/BooleanCheckedDataReader.java
deleted file mode 100644
index 49f6f00..0000000
--- a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/BooleanCheckedDataReader.java
+++ /dev/null
@@ -1,33 +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.solr.analytics.stream.reservation.read;
-
-import java.io.DataInput;
-import java.io.IOException;
-
-import org.apache.solr.analytics.util.function.BooleanConsumer;
-
-public class BooleanCheckedDataReader extends ReductionCheckedDataReader<BooleanConsumer> {
-  
-  public BooleanCheckedDataReader(DataInput inputStream, BooleanConsumer applier) {
-    super(inputStream, applier);
-  }
-  @Override
-  public void checkedRead() throws IOException {
-    applier.accept(inputStream.readBoolean());
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f0366b94/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/BooleanDataArrayReader.java
----------------------------------------------------------------------
diff --git a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/BooleanDataArrayReader.java b/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/BooleanDataArrayReader.java
deleted file mode 100644
index ee929f4..0000000
--- a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/BooleanDataArrayReader.java
+++ /dev/null
@@ -1,36 +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.solr.analytics.stream.reservation.read;
-
-import java.io.DataInput;
-import java.io.IOException;
-import java.util.function.IntConsumer;
-
-import org.apache.solr.analytics.util.function.BooleanConsumer;
-
-public class BooleanDataArrayReader extends ReductionDataArrayReader<BooleanConsumer> {
-  
-  public BooleanDataArrayReader(DataInput inputStream, BooleanConsumer applier, IntConsumer signal) {
-    super(inputStream, applier, signal);
-  }
-  @Override
-  public void read(int size) throws IOException {
-    for (int i = 0; i < size; ++i) {
-      applier.accept(inputStream.readBoolean());
-    }
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f0366b94/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/BooleanDataReader.java
----------------------------------------------------------------------
diff --git a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/BooleanDataReader.java b/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/BooleanDataReader.java
deleted file mode 100644
index 98e116d..0000000
--- a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/BooleanDataReader.java
+++ /dev/null
@@ -1,33 +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.solr.analytics.stream.reservation.read;
-
-import java.io.DataInput;
-import java.io.IOException;
-
-import org.apache.solr.analytics.util.function.BooleanConsumer;
-
-public class BooleanDataReader extends ReductionDataReader<BooleanConsumer> {
-  
-  public BooleanDataReader(DataInput inputStream, BooleanConsumer applier) {
-    super(inputStream, applier);
-  }
-  @Override
-  public void read() throws IOException {
-    applier.accept(inputStream.readBoolean());
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f0366b94/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/DoubleCheckedDataReader.java
----------------------------------------------------------------------
diff --git a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/DoubleCheckedDataReader.java b/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/DoubleCheckedDataReader.java
deleted file mode 100644
index ec6a6e4..0000000
--- a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/DoubleCheckedDataReader.java
+++ /dev/null
@@ -1,32 +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.solr.analytics.stream.reservation.read;
-
-import java.io.DataInput;
-import java.io.IOException;
-import java.util.function.DoubleConsumer;
-
-public class DoubleCheckedDataReader extends ReductionCheckedDataReader<DoubleConsumer> {
-  
-  public DoubleCheckedDataReader(DataInput inputStream, DoubleConsumer applier) {
-    super(inputStream, applier);
-  }
-  @Override
-  public void checkedRead() throws IOException {
-    applier.accept(inputStream.readDouble());
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f0366b94/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/DoubleDataArrayReader.java
----------------------------------------------------------------------
diff --git a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/DoubleDataArrayReader.java b/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/DoubleDataArrayReader.java
deleted file mode 100644
index 5690a45..0000000
--- a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/DoubleDataArrayReader.java
+++ /dev/null
@@ -1,35 +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.solr.analytics.stream.reservation.read;
-
-import java.io.DataInput;
-import java.io.IOException;
-import java.util.function.DoubleConsumer;
-import java.util.function.IntConsumer;
-
-public class DoubleDataArrayReader extends ReductionDataArrayReader<DoubleConsumer> {
-  
-  public DoubleDataArrayReader(DataInput inputStream, DoubleConsumer applier, IntConsumer signal) {
-    super(inputStream, applier, signal);
-  }
-  @Override
-  public void read(int size) throws IOException {
-    for (int i = 0; i < size; ++i) {
-      applier.accept(inputStream.readDouble());
-    }
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f0366b94/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/DoubleDataReader.java
----------------------------------------------------------------------
diff --git a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/DoubleDataReader.java b/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/DoubleDataReader.java
deleted file mode 100644
index 42de9bf..0000000
--- a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/DoubleDataReader.java
+++ /dev/null
@@ -1,32 +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.solr.analytics.stream.reservation.read;
-
-import java.io.DataInput;
-import java.io.IOException;
-import java.util.function.DoubleConsumer;
-
-public class DoubleDataReader extends ReductionDataReader<DoubleConsumer> {
-  
-  public DoubleDataReader(DataInput inputStream, DoubleConsumer applier) {
-    super(inputStream, applier);
-  }
-  @Override
-  public void read() throws IOException {
-    applier.accept(inputStream.readDouble());
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f0366b94/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/FloatCheckedDataReader.java
----------------------------------------------------------------------
diff --git a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/FloatCheckedDataReader.java b/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/FloatCheckedDataReader.java
deleted file mode 100644
index 8139cfb..0000000
--- a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/FloatCheckedDataReader.java
+++ /dev/null
@@ -1,33 +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.solr.analytics.stream.reservation.read;
-
-import java.io.DataInput;
-import java.io.IOException;
-
-import org.apache.solr.analytics.util.function.FloatConsumer;
-
-public class FloatCheckedDataReader extends ReductionCheckedDataReader<FloatConsumer> {
-  
-  public FloatCheckedDataReader(DataInput inputStream, FloatConsumer applier) {
-    super(inputStream, applier);
-  }
-  @Override
-  public void checkedRead() throws IOException {
-    applier.accept(inputStream.readFloat());
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f0366b94/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/FloatDataArrayReader.java
----------------------------------------------------------------------
diff --git a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/FloatDataArrayReader.java b/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/FloatDataArrayReader.java
deleted file mode 100644
index 1157a11..0000000
--- a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/FloatDataArrayReader.java
+++ /dev/null
@@ -1,36 +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.solr.analytics.stream.reservation.read;
-
-import java.io.DataInput;
-import java.io.IOException;
-import java.util.function.IntConsumer;
-
-import org.apache.solr.analytics.util.function.FloatConsumer;
-
-public class FloatDataArrayReader extends ReductionDataArrayReader<FloatConsumer> {
-  
-  public FloatDataArrayReader(DataInput inputStream, FloatConsumer applier, IntConsumer signal) {
-    super(inputStream, applier, signal);
-  }
-  @Override
-  public void read(int size) throws IOException {
-    for (int i = 0; i < size; ++i) {
-      applier.accept(inputStream.readFloat());
-    }
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f0366b94/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/FloatDataReader.java
----------------------------------------------------------------------
diff --git a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/FloatDataReader.java b/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/FloatDataReader.java
deleted file mode 100644
index 63067cd..0000000
--- a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/FloatDataReader.java
+++ /dev/null
@@ -1,33 +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.solr.analytics.stream.reservation.read;
-
-import java.io.DataInput;
-import java.io.IOException;
-
-import org.apache.solr.analytics.util.function.FloatConsumer;
-
-public class FloatDataReader extends ReductionDataReader<FloatConsumer> {
-  
-  public FloatDataReader(DataInput inputStream, FloatConsumer applier) {
-    super(inputStream, applier);
-  }
-  @Override
-  public void read() throws IOException {
-    applier.accept(inputStream.readFloat());
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f0366b94/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/IntCheckedDataReader.java
----------------------------------------------------------------------
diff --git a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/IntCheckedDataReader.java b/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/IntCheckedDataReader.java
deleted file mode 100644
index e926e3e..0000000
--- a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/IntCheckedDataReader.java
+++ /dev/null
@@ -1,32 +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.solr.analytics.stream.reservation.read;
-
-import java.io.DataInput;
-import java.io.IOException;
-import java.util.function.IntConsumer;
-
-public class IntCheckedDataReader extends ReductionCheckedDataReader<IntConsumer> {
-  
-  public IntCheckedDataReader(DataInput inputStream, IntConsumer applier) {
-    super(inputStream, applier);
-  }
-  @Override
-  public void checkedRead() throws IOException {
-    applier.accept(inputStream.readInt());
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f0366b94/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/IntDataArrayReader.java
----------------------------------------------------------------------
diff --git a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/IntDataArrayReader.java b/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/IntDataArrayReader.java
deleted file mode 100644
index a0c1d86..0000000
--- a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/IntDataArrayReader.java
+++ /dev/null
@@ -1,34 +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.solr.analytics.stream.reservation.read;
-
-import java.io.DataInput;
-import java.io.IOException;
-import java.util.function.IntConsumer;
-
-public class IntDataArrayReader extends ReductionDataArrayReader<IntConsumer> {
-  
-  public IntDataArrayReader(DataInput inputStream, IntConsumer applier, IntConsumer signal) {
-    super(inputStream, applier, signal);
-  }
-  @Override
-  public void read(int size) throws IOException {
-    for (int i = 0; i < size; ++i) {
-      applier.accept(inputStream.readInt());
-    }
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f0366b94/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/IntDataReader.java
----------------------------------------------------------------------
diff --git a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/IntDataReader.java b/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/IntDataReader.java
deleted file mode 100644
index 5b65055..0000000
--- a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/IntDataReader.java
+++ /dev/null
@@ -1,32 +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.solr.analytics.stream.reservation.read;
-
-import java.io.DataInput;
-import java.io.IOException;
-import java.util.function.IntConsumer;
-
-public class IntDataReader extends ReductionDataReader<IntConsumer> {
-  
-  public IntDataReader(DataInput inputStream, IntConsumer applier) {
-    super(inputStream, applier);
-  }
-  @Override
-  public void read() throws IOException {
-    applier.accept(inputStream.readInt());
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f0366b94/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/LongCheckedDataReader.java
----------------------------------------------------------------------
diff --git a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/LongCheckedDataReader.java b/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/LongCheckedDataReader.java
deleted file mode 100644
index 7d9a7ff..0000000
--- a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/LongCheckedDataReader.java
+++ /dev/null
@@ -1,32 +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.solr.analytics.stream.reservation.read;
-
-import java.io.DataInput;
-import java.io.IOException;
-import java.util.function.LongConsumer;
-
-public class LongCheckedDataReader extends ReductionCheckedDataReader<LongConsumer> {
-  
-  public LongCheckedDataReader(DataInput inputStream, LongConsumer applier) {
-    super(inputStream, applier);
-  }
-  @Override
-  public void checkedRead() throws IOException {
-    applier.accept(inputStream.readLong());
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f0366b94/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/LongDataArrayReader.java
----------------------------------------------------------------------
diff --git a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/LongDataArrayReader.java b/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/LongDataArrayReader.java
deleted file mode 100644
index 6c09f46..0000000
--- a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/LongDataArrayReader.java
+++ /dev/null
@@ -1,35 +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.solr.analytics.stream.reservation.read;
-
-import java.io.DataInput;
-import java.io.IOException;
-import java.util.function.IntConsumer;
-import java.util.function.LongConsumer;
-
-public class LongDataArrayReader extends ReductionDataArrayReader<LongConsumer> {
-  
-  public LongDataArrayReader(DataInput inputStream, LongConsumer applier, IntConsumer signal) {
-    super(inputStream, applier, signal);
-  }
-  @Override
-  public void read(int size) throws IOException {
-    for (int i = 0; i < size; ++i) {
-      applier.accept(inputStream.readLong());
-    }
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f0366b94/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/LongDataReader.java
----------------------------------------------------------------------
diff --git a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/LongDataReader.java b/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/LongDataReader.java
deleted file mode 100644
index bf4057d..0000000
--- a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/LongDataReader.java
+++ /dev/null
@@ -1,32 +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.solr.analytics.stream.reservation.read;
-
-import java.io.DataInput;
-import java.io.IOException;
-import java.util.function.LongConsumer;
-
-public class LongDataReader extends ReductionDataReader<LongConsumer> {
-  
-  public LongDataReader(DataInput inputStream, LongConsumer applier) {
-    super(inputStream, applier);
-  }
-  @Override
-  public void read() throws IOException {
-    applier.accept(inputStream.readLong());
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f0366b94/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/ReductionCheckedDataReader.java
----------------------------------------------------------------------
diff --git a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/ReductionCheckedDataReader.java b/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/ReductionCheckedDataReader.java
deleted file mode 100644
index ac98987..0000000
--- a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/ReductionCheckedDataReader.java
+++ /dev/null
@@ -1,54 +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.solr.analytics.stream.reservation.read;
-
-import java.io.DataInput;
-import java.io.IOException;
-
-/**
- * Abstract class to manage the reading and application of data from a {@link DataInput} stream.
- * The data being read may not exist, so the reader first checks before reading.
- */
-public abstract class ReductionCheckedDataReader<A> extends ReductionDataReader<A> {
-  
-  public ReductionCheckedDataReader(DataInput inputStream, A applier) {
-    super(inputStream, applier);
-  }
-  
-  @Override
-  /**
-   * Read a piece of data from the input stream and feed it to the applier.
-   * <br>
-   * First checks that the piece of data exists before reading.
-   * 
-   * @throws IOException if an exception occurs while reading from the input stream
-   */
-  public void read() throws IOException {
-    if (inputStream.readBoolean()) {
-      checkedRead();
-    }
-  }
-  
-  /**
-   * Read a piece of data from the input stream and feed it to the applier.
-   * <br>
-   * This piece of data is guaranteed to be there.
-   * 
-   * @throws IOException if an exception occurs while reading from the input stream
-   */
-  protected abstract void checkedRead() throws IOException;
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/f0366b94/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/ReductionDataArrayReader.java
----------------------------------------------------------------------
diff --git a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/ReductionDataArrayReader.java b/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/ReductionDataArrayReader.java
deleted file mode 100644
index 2a696d7..0000000
--- a/solr/contrib/analytics/src/java/org/apache/solr/analytics/stream/reservation/read/ReductionDataArrayReader.java
+++ /dev/null
@@ -1,54 +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.solr.analytics.stream.reservation.read;
-
-import java.io.DataInput;
-import java.io.IOException;
-import java.util.function.IntConsumer;
-
-/**
- * Abstract class to manage the reading and application of array data from a {@link DataInput} stream.
- */
-public abstract class ReductionDataArrayReader<A> extends ReductionDataReader<A> {
-  protected final IntConsumer signal;
-  
-  public ReductionDataArrayReader(DataInput inputStream, A applier, IntConsumer signal) {
-    super(inputStream, applier);
-    
-    this.signal = signal;
-  }
-  
-  @Override
-  /**
-   * Read an array of data from the input stream and feed it to the applier, first signaling the size of the array.
-   * 
-   * @throws IOException if an exception occurs while reading from the input stream
-   */
-  public void read() throws IOException {
-    int size = inputStream.readInt();
-    signal.accept(size);
-    read(size);
-  }
-  
-  /**
-   * Read an array from the input stream, feeding each member to the applier.
-   * 
-   * @param size length of the array to read
-   * @throws IOException if an exception occurs while reading from the input stream
-   */
-  protected abstract void read(int size) throws IOException;
-}
\ No newline at end of file