| Modifier and Type | Class and Description | 
|---|---|
class  | 
DoublesSketchObjectStrategy  | 
| Modifier and Type | Method and Description | 
|---|---|
ObjectStrategy<com.yahoo.sketches.quantiles.DoublesSketch> | 
DoublesSketchComplexMetricSerde.getObjectStrategy()  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
SketchObjectStrategy  | 
| Modifier and Type | Method and Description | 
|---|---|
ObjectStrategy<com.yahoo.sketches.theta.Sketch> | 
SketchMergeComplexMetricSerde.getObjectStrategy()  | 
| Modifier and Type | Method and Description | 
|---|---|
ObjectStrategy | 
ApproximateHistogramFoldingSerde.getObjectStrategy()  | 
| Modifier and Type | Method and Description | 
|---|---|
ObjectStrategy | 
HyperUniquesSerde.getObjectStrategy()  | 
| Modifier and Type | Method and Description | 
|---|---|
ObjectStrategy | 
VarianceSerde.getObjectStrategy()  | 
| Modifier and Type | Method and Description | 
|---|---|
static MetricHolder | 
MetricHolder.fromByteBuffer(ByteBuffer buf,
              ObjectStrategy strategy,
              SmooshedFileMapper mapper)  | 
| Modifier and Type | Interface and Description | 
|---|---|
interface  | 
CacheableObjectStrategy<T>
Implementing CacheableObjectStrategy instead of ObjectSrategy indicates
 that a column scan may cache the results of  
fromByteBuffer(java.nio.ByteBuffer, int). | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
DecompressingByteBufferObjectStrategy  | 
class  | 
ImmutableRTreeObjectStrategy  | 
| Modifier and Type | Field and Description | 
|---|---|
static ObjectStrategy<String> | 
GenericIndexed.STRING_STRATEGY  | 
| Modifier and Type | Method and Description | 
|---|---|
ObjectStrategy<ImmutableBitmap> | 
RoaringBitmapSerdeFactory.getObjectStrategy()  | 
ObjectStrategy<ImmutableBitmap> | 
ConciseBitmapSerdeFactory.getObjectStrategy()  | 
ObjectStrategy<ImmutableBitmap> | 
BitmapSerdeFactory.getObjectStrategy()  | 
| Modifier and Type | Method and Description | 
|---|---|
static <T> GenericIndexed<T> | 
GenericIndexed.fromArray(T[] objects,
         ObjectStrategy<T> strategy)  | 
static <T> GenericIndexed<T> | 
GenericIndexed.fromIterable(Iterable<T> objectsIterable,
            ObjectStrategy<T> strategy)  | 
static <T> GenericIndexed<T> | 
GenericIndexed.read(ByteBuffer buffer,
    ObjectStrategy<T> strategy)  | 
static <T> GenericIndexed<T> | 
GenericIndexed.read(ByteBuffer buffer,
    ObjectStrategy<T> strategy,
    SmooshedFileMapper fileMapper)  | 
| Constructor and Description | 
|---|
ByteBufferWriter(SegmentWriteOutMedium segmentWriteOutMedium,
                ObjectStrategy<T> strategy)  | 
GenericIndexedWriter(SegmentWriteOutMedium segmentWriteOutMedium,
                    String filenameBase,
                    ObjectStrategy<T> strategy)  | 
GenericIndexedWriter(SegmentWriteOutMedium segmentWriteOutMedium,
                    String filenameBase,
                    ObjectStrategy<T> strategy,
                    int fileSizeLimit)  | 
| Modifier and Type | Method and Description | 
|---|---|
abstract ObjectStrategy | 
ComplexMetricSerde.getObjectStrategy()
Deprecated.  
 | 
| Modifier and Type | Method and Description | 
|---|---|
static LargeColumnSupportedComplexColumnSerializer | 
LargeColumnSupportedComplexColumnSerializer.create(SegmentWriteOutMedium segmentWriteOutMedium,
      String filenameBase,
      ObjectStrategy strategy)  | 
static ComplexColumnSerializer | 
ComplexColumnSerializer.create(SegmentWriteOutMedium segmentWriteOutMedium,
      String filenameBase,
      ObjectStrategy strategy)  | 
static LargeColumnSupportedComplexColumnSerializer | 
LargeColumnSupportedComplexColumnSerializer.createWithColumnSize(SegmentWriteOutMedium segmentWriteOutMedium,
                    String filenameBase,
                    ObjectStrategy strategy,
                    int columnSize)  | 
Copyright © 2011–2018. All rights reserved.