- AbstractHollowAPIGeneratorBuilder<B extends AbstractHollowAPIGeneratorBuilder<?,?>,G extends HollowAPIGenerator> - Class in com.netflix.hollow.api.codegen
-
Abstract Hollow API Generator Builder - to be extended to create customized Builders
- AbstractHollowAPIGeneratorBuilder() - Constructor for class com.netflix.hollow.api.codegen.AbstractHollowAPIGeneratorBuilder
-
- AbstractHollowDataAccessor<T> - Class in com.netflix.hollow.api.consumer.data
-
- AbstractHollowDataAccessor(HollowConsumer, String) - Constructor for class com.netflix.hollow.api.consumer.data.AbstractHollowDataAccessor
-
- AbstractHollowDataAccessor(HollowReadStateEngine, String) - Constructor for class com.netflix.hollow.api.consumer.data.AbstractHollowDataAccessor
-
- AbstractHollowDataAccessor(HollowReadStateEngine, String, String...) - Constructor for class com.netflix.hollow.api.consumer.data.AbstractHollowDataAccessor
-
- AbstractHollowDataAccessor(HollowReadStateEngine, String, PrimaryKey) - Constructor for class com.netflix.hollow.api.consumer.data.AbstractHollowDataAccessor
-
- AbstractHollowDataAccessor.UpdatedRecord<T> - Class in com.netflix.hollow.api.consumer.data
-
Keeps track of record before and after Update
- AbstractHollowHashIndex<API> - Class in com.netflix.hollow.api.consumer.index
-
- AbstractHollowHashIndex(HollowConsumer, boolean, String, String, String...) - Constructor for class com.netflix.hollow.api.consumer.index.AbstractHollowHashIndex
-
Deprecated.
- AbstractHollowOrdinalIterable<T> - Class in com.netflix.hollow.api.consumer.data
-
- AbstractHollowOrdinalIterable(HollowOrdinalIterator) - Constructor for class com.netflix.hollow.api.consumer.data.AbstractHollowOrdinalIterable
-
- AbstractHollowProducerListener - Class in com.netflix.hollow.api.producer
-
- AbstractHollowProducerListener() - Constructor for class com.netflix.hollow.api.producer.AbstractHollowProducerListener
-
- AbstractHollowUniqueKeyIndex<API,T> - Class in com.netflix.hollow.api.consumer.index
-
Intended for internal use only - used by API code generator
,
- AbstractHollowUniqueKeyIndex(HollowConsumer, String, boolean, String...) - Constructor for class com.netflix.hollow.api.consumer.index.AbstractHollowUniqueKeyIndex
-
- AbstractIncrementalCycleListener - Class in com.netflix.hollow.api.producer
-
- AbstractIncrementalCycleListener() - Constructor for class com.netflix.hollow.api.producer.AbstractIncrementalCycleListener
-
Deprecated.
- AbstractProducerMetricsListener - Class in com.netflix.hollow.api.producer.metrics
-
A class for computing Hollow Producer metrics, that requires extending subclasses to implement custom metrics reporting.
- AbstractProducerMetricsListener() - Constructor for class com.netflix.hollow.api.producer.metrics.AbstractProducerMetricsListener
-
- AbstractRefreshListener() - Constructor for class com.netflix.hollow.api.consumer.HollowConsumer.AbstractRefreshListener
-
- AbstractRefreshMetricsListener - Class in com.netflix.hollow.api.consumer.metrics
-
A class for computing Hollow Consumer refresh metrics, requires plugging in metrics reporting implementation.
- AbstractRefreshMetricsListener() - Constructor for class com.netflix.hollow.api.consumer.metrics.AbstractRefreshMetricsListener
-
- AbstractSingleProducerEnforcer - Class in com.netflix.hollow.api.producer.enforcer
-
- AbstractSingleProducerEnforcer() - Constructor for class com.netflix.hollow.api.producer.enforcer.AbstractSingleProducerEnforcer
-
- add(HollowConsumer.Blob) - Method in class com.netflix.hollow.api.client.HollowUpdatePlan
-
- add(Object) - Method in interface com.netflix.hollow.api.producer.HollowProducer.WriteState
-
Adds the specified POJO to the state engine.
- add(int, int) - Method in class com.netflix.hollow.core.index.MultiLinkedElementArray
-
- add(int) - Method in class com.netflix.hollow.core.util.IntList
-
- add(long) - Method in class com.netflix.hollow.core.util.LongList
-
- add(HollowWriteRecord) - Method in class com.netflix.hollow.core.write.HollowTypeWriteState
-
Add an object to this state.
- add(String, HollowWriteRecord) - Method in class com.netflix.hollow.core.write.HollowWriteStateEngine
-
Add a record to the state.
- add(Object) - Method in class com.netflix.hollow.core.write.objectmapper.HollowObjectMapper
-
Adds the specified POJO to the state engine.
- ADD_REFERENCING_OUTSIDE_CLOSURE - Static variable in interface com.netflix.hollow.tools.traverse.TransitiveSetTraverser.TransitiveSetTraverserAction
-
- addAll(IntList) - Method in class com.netflix.hollow.core.util.IntList
-
- addAllCycleMetadata(Map<String, Object>) - Method in class com.netflix.hollow.api.producer.HollowIncrementalProducer
-
Deprecated.
- addAllObjectsFromPreviousCycle() - Method in class com.netflix.hollow.core.write.HollowTypeWriteState
-
- addAllObjectsFromPreviousCycle() - Method in class com.netflix.hollow.core.write.HollowWriteStateEngine
-
Add all of the objects from the previous cycle, exactly as they were in the previous cycle.
- addCycleMetadata(String, Object) - Method in class com.netflix.hollow.api.producer.HollowIncrementalProducer
-
Deprecated.
- addDiff(int, int, int) - Method in class com.netflix.hollow.tools.diff.count.HollowFieldDiff
-
Should be called exclusively from the
HollowDiff
-- not intended for external consumption
- added(HollowTypeReadState, int) - Method in class com.netflix.hollow.tools.history.keyindex.HollowHistoricalStateTypeKeyOrdinalMapping
-
- addedOrdinal(int) - Method in class com.netflix.hollow.api.objects.provider.HollowObjectCacheProvider
-
- addedOrdinal(int) - Method in class com.netflix.hollow.core.index.HollowHashIndex
-
- addedOrdinal(int) - Method in class com.netflix.hollow.core.index.HollowPrefixIndex
-
- addedOrdinal(int) - Method in class com.netflix.hollow.core.index.HollowPrimaryKeyIndex
-
- addedOrdinal(int) - Method in class com.netflix.hollow.core.index.HollowSparseIntegerSet
-
- addedOrdinal(int) - Method in interface com.netflix.hollow.core.read.engine.HollowTypeStateListener
-
Called once for each record which is added to the registered type.
- addedOrdinal(int) - Method in class com.netflix.hollow.core.read.engine.PopulatedOrdinalListener
-
- addedOrdinalMappingIterator() - Method in class com.netflix.hollow.tools.history.keyindex.HollowHistoricalStateTypeKeyOrdinalMapping
-
- addElement(long, long) - Method in class com.netflix.hollow.core.memory.encoding.FixedLengthMultipleOccurrenceElementArray
-
This method adds an element at nodeIndex.
- addElement(int) - Method in class com.netflix.hollow.core.write.HollowListWriteRecord
-
- addElement(int) - Method in class com.netflix.hollow.core.write.HollowSetWriteRecord
-
- addElement(int, int) - Method in class com.netflix.hollow.core.write.HollowSetWriteRecord
-
- addEntry(int, int) - Method in class com.netflix.hollow.core.write.HollowMapWriteRecord
-
- addEntry(int, int, int) - Method in class com.netflix.hollow.core.write.HollowMapWriteRecord
-
- addExcludeObjectTypes(String...) - Method in class com.netflix.hollow.tools.stringifier.HollowRecordJsonStringifier
-
- addExcludeObjectTypes(String...) - Method in class com.netflix.hollow.tools.stringifier.HollowRecordStringifier
-
- addExcludeObjectTypes(String...) - Method in interface com.netflix.hollow.tools.stringifier.HollowStringifier
-
Exclude specified object types (replace output with null).
- addField(String, String) - Method in class com.netflix.hollow.core.read.filter.HollowFilterConfig
-
Deprecated.
Add an individual field from an OBJECT schema.
- addField(String, HollowObjectSchema.FieldType) - Method in class com.netflix.hollow.core.schema.HollowObjectSchema
-
- addField(String, HollowObjectSchema.FieldType, String) - Method in class com.netflix.hollow.core.schema.HollowObjectSchema
-
- addField(String, HollowObjectSchema.FieldType, String, HollowTypeReadState) - Method in class com.netflix.hollow.core.schema.HollowObjectSchema
-
- addFieldIndex(String, HollowDataset) - Method in class com.netflix.hollow.tools.history.keyindex.HollowHistoryTypeKeyIndex
-
- addFieldRecursive(String, String, Collection<HollowSchema>) - Method in class com.netflix.hollow.core.read.filter.HollowFilterConfig
-
Deprecated.
Add an individual field from an OBJECT schema, plus recursively add any directly or transitively referenced types.
- addFieldRecursive(String, String, Map<String, HollowSchema>) - Method in class com.netflix.hollow.core.read.filter.HollowFilterConfig
-
Deprecated.
Add an individual field from an OBJECT schema, plus recursively add any directly or transitively referenced types.
- addFixedLengthFieldRequiredBits(int, int) - Method in class com.netflix.hollow.core.write.FieldStatistics
-
- addHeaderTag(String, String) - Method in class com.netflix.hollow.core.write.HollowWriteStateEngine
-
- addHeaderTags(Map<String, String>) - Method in class com.netflix.hollow.core.write.HollowWriteStateEngine
-
- addIfAbsent(Object) - Method in class com.netflix.hollow.api.producer.HollowIncrementalProducer
-
Deprecated.
- addIfAbsent(FlatRecord) - Method in class com.netflix.hollow.api.producer.HollowIncrementalProducer
-
Deprecated.
- addIfAbsent(Object) - Method in interface com.netflix.hollow.api.producer.HollowProducer.Incremental.IncrementalWriteState
-
Adds a new object.
- addIgnoredTypes(String...) - Method in class com.netflix.hollow.tools.combine.HollowCombiner
-
Specify a set of types not to copy.
- addInput(String, File) - Method in class com.netflix.hollow.core.read.OptionalBlobPartInput
-
- addInput(String, InputStream) - Method in class com.netflix.hollow.core.read.OptionalBlobPartInput
-
- addListener(EventListener) - Method in class com.netflix.hollow.api.common.ListenerSupport
-
- addListener(IncrementalCycleListener) - Method in class com.netflix.hollow.api.producer.HollowIncrementalProducer
-
Deprecated.
- addListener(HollowProducerListener) - Method in class com.netflix.hollow.api.producer.HollowProducer
-
Adds a listener to this producer.
- addListener(HollowProducerEventListener) - Method in class com.netflix.hollow.api.producer.HollowProducer
-
Adds a listener to this producer.
- addListener(HollowTypeStateListener) - Method in class com.netflix.hollow.core.read.engine.HollowTypeReadState
-
- addMatchingValue(Object...) - Method in class com.netflix.hollow.tools.patch.record.TypeMatchSpec
-
- addMatchPath(String) - Method in class com.netflix.hollow.tools.diff.HollowDiffMatcher
-
- addMatchPath(String) - Method in class com.netflix.hollow.tools.diff.HollowTypeDiff
-
Add a field path to a component of the primary key
- addObject(Object) - Method in class com.netflix.hollow.core.write.objectmapper.HollowObjectMapper
-
- addOrdinalFromPreviousCycle(int) - Method in class com.netflix.hollow.core.write.HollowTypeWriteState
-
- addOrdinalRemapping(String, IntMap) - Method in class com.netflix.hollow.tools.history.IntMapOrdinalRemapper
-
- addOrdinalRemapping(String, IntMap) - Method in class com.netflix.hollow.tools.patch.delta.PartialOrdinalRemapper
-
- addOrModify(Object) - Method in class com.netflix.hollow.api.producer.HollowIncrementalProducer
-
Deprecated.
- addOrModify(Collection<Object>) - Method in class com.netflix.hollow.api.producer.HollowIncrementalProducer
-
Deprecated.
- addOrModify(FlatRecord) - Method in class com.netflix.hollow.api.producer.HollowIncrementalProducer
-
Deprecated.
- addOrModify(Object) - Method in interface com.netflix.hollow.api.producer.HollowProducer.Incremental.IncrementalWriteState
-
Adds a new object or modifies an existing object.
- addOrModifyInParallel(Collection<Object>) - Method in class com.netflix.hollow.api.producer.HollowIncrementalProducer
-
Deprecated.
- addOutputStream(String, OutputStream) - Method in class com.netflix.hollow.api.producer.ProducerOptionalBlobPartConfig.OptionalBlobPartOutputStreams
-
- addReferencingOutsideClosure(HollowReadStateEngine, Map<String, BitSet>) - Static method in class com.netflix.hollow.tools.traverse.TransitiveSetTraverser
-
Augment the given selection with any records outside the selection which reference
(or transitively reference) any records in the selection.
- addRefreshListener(HollowConsumer.RefreshListener, HollowConsumer) - Method in class com.netflix.hollow.api.client.HollowClientUpdater
-
- addRefreshListener(HollowConsumer.RefreshListener) - Method in class com.netflix.hollow.api.consumer.HollowConsumer
-
- addReplicatedTypes(String...) - Method in class com.netflix.hollow.tools.split.HollowSplitterPrimaryKeyCopyDirector
-
- addResults(HollowFieldDiff) - Method in class com.netflix.hollow.tools.diff.count.HollowFieldDiff
-
This should be called exclusively from the
HollowDiff
.
- addSamplingStatusListener(SamplingStatusListener) - Method in class com.netflix.hollow.api.sampling.TimeSliceSamplingDirector
-
- addShortcutType(String) - Method in class com.netflix.hollow.tools.diff.HollowTypeDiff
-
Shortcut the diff detail when encountering a specific type.
- addTransitiveMatches(HollowReadStateEngine, Map<String, BitSet>) - Static method in class com.netflix.hollow.tools.traverse.TransitiveSetTraverser
-
Augment the given selection by adding the references, and the transitive references, of our selection.
- addType(String) - Method in class com.netflix.hollow.core.read.filter.HollowFilterConfig
-
Deprecated.
Add a type.
- addTypeAPI(HollowTypeAPI) - Method in class com.netflix.hollow.api.custom.HollowAPI
-
- addTypeDiff(String, String...) - Method in class com.netflix.hollow.tools.diff.HollowDiff
-
Add a type to be included in the diff report
- addTypeIndex(String, String...) - Method in class com.netflix.hollow.tools.history.keyindex.HollowHistoryKeyIndex
-
- addTypeIndex(PrimaryKey) - Method in class com.netflix.hollow.tools.history.keyindex.HollowHistoryKeyIndex
-
- addTypeIndex(PrimaryKey, HollowDataset) - Method in class com.netflix.hollow.tools.history.keyindex.HollowHistoryKeyIndex
-
- addTypeListener(String, HollowTypeStateListener) - Method in class com.netflix.hollow.core.read.engine.HollowReadStateEngine
-
- addTypeMatchSpec(TypeMatchSpec) - Method in class com.netflix.hollow.tools.patch.record.HollowStateEngineRecordPatcher
-
- addTypeRecursive(String, Collection<HollowSchema>) - Method in class com.netflix.hollow.core.read.filter.HollowFilterConfig
-
Deprecated.
Add a type, plus recursively add any directly or transitively referenced types.
- addTypeRecursive(String, Map<String, HollowSchema>) - Method in class com.netflix.hollow.core.read.filter.HollowFilterConfig
-
Deprecated.
Add a type, plus recursively add any directly or transitively referenced types.
- addTypeState(HollowTypeReadState) - Method in class com.netflix.hollow.core.read.engine.HollowReadStateEngine
-
- addTypeState(HollowTypeWriteState) - Method in class com.netflix.hollow.core.write.HollowWriteStateEngine
-
Add a type to the dataset.
- addTypeState(HollowWriteStateEngine) - Method in class com.netflix.hollow.core.write.objectmapper.HollowTypeMapper
-
- addTypesToPart(String, String...) - Method in class com.netflix.hollow.api.producer.ProducerOptionalBlobPartConfig
-
- addValidatorsForSchemaWithPrimaryKey(HollowProducer) - Static method in class com.netflix.hollow.api.producer.validation.DuplicateDataDetectionValidator
-
Registers
DuplicateDataDetectionValidator
validators with the given
producer
for
all object schema declared with a primary key.
- addVarLengthFieldSize(int, int) - Method in class com.netflix.hollow.core.write.FieldStatistics
-
- advance() - Method in class com.netflix.hollow.core.memory.encoding.GapEncodedVariableLengthIntegerReader
-
- afterInitialization() - Method in class com.netflix.hollow.core.read.engine.HollowReadStateEngine
-
- AllHollowRecordCollection<T> - Class in com.netflix.hollow.core.util
-
- AllHollowRecordCollection(HollowTypeReadState) - Constructor for class com.netflix.hollow.core.util.AllHollowRecordCollection
-
- allowDoubleSnapshot() - Method in interface com.netflix.hollow.api.client.HollowClientMemoryConfig
-
Deprecated.
- allowDoubleSnapshot() - Method in class com.netflix.hollow.api.client.HollowClientMemoryConfig.SpecifiedConfig
-
Deprecated.
- allowDoubleSnapshot() - Method in interface com.netflix.hollow.api.consumer.HollowConsumer.DoubleSnapshotConfig
-
- andNot(ThreadSafeBitSet) - Method in class com.netflix.hollow.core.memory.ThreadSafeBitSet
-
Return a new bit set which contains all bits which are contained in this bit set, and which are NOT contained in the other
bit set.
- announce(long) - Method in class com.netflix.hollow.api.producer.fs.HollowFilesystemAnnouncer
-
- announce(long) - Method in interface com.netflix.hollow.api.producer.HollowProducer.Announcer
-
- announce(long, Map<String, String>) - Method in interface com.netflix.hollow.api.producer.HollowProducer.Announcer
-
- ANNOUNCEMENT_FILENAME - Static variable in class com.netflix.hollow.api.producer.fs.HollowFilesystemAnnouncer
-
- ANNOUNCEMENT_FILENAME_TEMPORARY - Static variable in class com.netflix.hollow.api.producer.fs.HollowFilesystemAnnouncer
-
- AnnouncementListener - Interface in com.netflix.hollow.api.producer.listener
-
A listener of announcement events associated with the producer announcement stage.
- AnnouncementMetrics - Class in com.netflix.hollow.api.producer.metrics
-
- AnnouncementMetrics.Builder - Class in com.netflix.hollow.api.producer.metrics
-
- announcementMetricsReporting(AnnouncementMetrics) - Method in interface com.netflix.hollow.api.producer.metrics.ProducerMetricsReporting
-
- announcementWatcher - Variable in class com.netflix.hollow.api.client.HollowClient
-
Deprecated.
- announcementWatcher - Variable in class com.netflix.hollow.api.consumer.HollowConsumer
-
- announcementWatcher - Variable in class com.netflix.hollow.api.consumer.HollowConsumer.Builder
-
- announcementWatcher - Variable in class com.netflix.hollow.api.producer.HollowIncrementalProducer.Builder
-
Deprecated.
- anyTransitionWasFailed(HollowUpdatePlan) - Method in class com.netflix.hollow.api.client.FailedTransitionTracker
-
- api - Variable in class com.netflix.hollow.api.consumer.index.AbstractHollowHashIndex
-
Deprecated.
- api - Variable in class com.netflix.hollow.api.consumer.index.AbstractHollowUniqueKeyIndex
-
- api - Variable in class com.netflix.hollow.api.custom.HollowTypeAPI
-
- api() - Method in class com.netflix.hollow.core.type.HBoolean
-
- api() - Method in class com.netflix.hollow.core.type.HDouble
-
- api() - Method in class com.netflix.hollow.core.type.HFloat
-
- api() - Method in class com.netflix.hollow.core.type.HInteger
-
- api() - Method in class com.netflix.hollow.core.type.HLong
-
- api() - Method in class com.netflix.hollow.core.type.HString
-
- apiClassname - Variable in class com.netflix.hollow.api.codegen.AbstractHollowAPIGeneratorBuilder
-
- apiclassName - Variable in class com.netflix.hollow.api.codegen.api.HollowDataAccessorGenerator
-
- apiClassname - Variable in class com.netflix.hollow.api.codegen.api.HollowTypeAPIGenerator
-
- apiClassname - Variable in class com.netflix.hollow.api.codegen.HollowAPIGenerator
-
- apiClassname - Variable in class com.netflix.hollow.api.codegen.indexes.HollowIndexGenerator
-
- apiClassname - Variable in class com.netflix.hollow.api.codegen.objects.HollowCollectionsGenerator
-
- apiFactory - Variable in class com.netflix.hollow.api.consumer.HollowConsumer.Builder
-
- appendPackageAndCommonImports(StringBuilder) - Method in class com.netflix.hollow.api.codegen.HollowConsumerJavaFileGenerator
-
- appendPackageAndCommonImports(StringBuilder, String) - Method in class com.netflix.hollow.api.codegen.HollowConsumerJavaFileGenerator
-
- appendPackageAndCommonImports(StringBuilder, String, List<HollowSchema>) - Method in class com.netflix.hollow.api.codegen.HollowConsumerJavaFileGenerator
-
- appendPlan(HollowUpdatePlan) - Method in class com.netflix.hollow.api.client.HollowUpdatePlan
-
- apply(Q) - Method in class com.netflix.hollow.api.consumer.index.HashIndexSelect
-
Finds matches for a given query.
- apply(Q) - Method in class com.netflix.hollow.api.consumer.index.UniqueKeyIndex
-
Finds the unique object, an instance of the unique type, for a given key.
- applyDelta(InputStream) - Method in class com.netflix.hollow.core.read.engine.HollowBlobReader
-
Update the state engine using a delta (or reverse delta) blob from the provided input stream.
- applyDelta(HollowBlobInput) - Method in class com.netflix.hollow.core.read.engine.HollowBlobReader
-
Update the state engine using a delta (or reverse delta) blob from the provided HollowBlobInput.
- applyDelta(HollowBlobInput, OptionalBlobPartInput) - Method in class com.netflix.hollow.core.read.engine.HollowBlobReader
-
- applyDelta(HollowBlobInput, HollowSchema, ArraySegmentRecycler) - Method in class com.netflix.hollow.core.read.engine.HollowTypeReadState
-
- applyDelta(HollowListTypeDataElements, HollowListTypeDataElements) - Method in class com.netflix.hollow.core.read.engine.list.HollowListTypeDataElements
-
- applyDelta(HollowBlobInput, HollowSchema, ArraySegmentRecycler) - Method in class com.netflix.hollow.core.read.engine.list.HollowListTypeReadState
-
- applyDelta(HollowMapTypeDataElements, HollowMapTypeDataElements) - Method in class com.netflix.hollow.core.read.engine.map.HollowMapTypeDataElements
-
- applyDelta(HollowBlobInput, HollowSchema, ArraySegmentRecycler) - Method in class com.netflix.hollow.core.read.engine.map.HollowMapTypeReadState
-
- applyDelta(HollowBlobInput, HollowSchema, ArraySegmentRecycler) - Method in class com.netflix.hollow.core.read.engine.object.HollowObjectTypeReadState
-
- applyDelta(HollowSetTypeDataElements, HollowSetTypeDataElements) - Method in class com.netflix.hollow.core.read.engine.set.HollowSetTypeDataElements
-
- applyDelta(HollowBlobInput, HollowSchema, ArraySegmentRecycler) - Method in class com.netflix.hollow.core.read.engine.set.HollowSetTypeReadState
-
- applyInt(int) - Method in class com.netflix.hollow.tools.checksum.HollowChecksum
-
- applyLong(long) - Method in class com.netflix.hollow.tools.checksum.HollowChecksum
-
- applyToChecksum(HollowChecksum, HollowSchema) - Method in class com.netflix.hollow.core.read.engine.HollowTypeReadState
-
- applyToChecksum(HollowChecksum, HollowSchema) - Method in class com.netflix.hollow.core.read.engine.list.HollowListTypeReadState
-
- applyToChecksum(HollowChecksum, HollowSchema) - Method in class com.netflix.hollow.core.read.engine.map.HollowMapTypeReadState
-
- applyToChecksum(HollowChecksum, HollowSchema) - Method in class com.netflix.hollow.core.read.engine.object.HollowObjectTypeReadState
-
- applyToChecksum(HollowChecksum, HollowSchema) - Method in class com.netflix.hollow.core.read.engine.set.HollowSetTypeReadState
-
- ArgumentParser<T extends java.lang.Enum> - Class in com.netflix.hollow.api.codegen
-
- ArgumentParser(Class<T>, String[]) - Constructor for class com.netflix.hollow.api.codegen.ArgumentParser
-
- ArgumentParser.ParsedArgument - Class in com.netflix.hollow.api.codegen
-
- ArrayByteData - Class in com.netflix.hollow.core.memory
-
A ByteData backed by a simple array of bytes.
- ArrayByteData(byte[]) - Constructor for class com.netflix.hollow.core.memory.ArrayByteData
-
- arrayCopyOfRange(int, int) - Method in class com.netflix.hollow.core.util.IntList
-
- ArraySegmentRecycler - Interface in com.netflix.hollow.core.memory.pool
-
An ArraySegmentRecycler is a memory pool.
- ASSIGNED_ORDINAL_CYCLE_MASK - Static variable in class com.netflix.hollow.core.write.objectmapper.HollowTypeMapper
-
- awaitSuccessfulCompletion() - Method in class com.netflix.hollow.core.util.SimultaneousExecutor
-
Await successful completion of all submitted tasks.
- awaitSuccessfulCompletionOfCurrentTasks() - Method in class com.netflix.hollow.core.util.SimultaneousExecutor
-
Await successful completion of all previously submitted tasks.
- awaitUninterruptibly() - Method in class com.netflix.hollow.core.util.SimultaneousExecutor
-
Awaits completion of all submitted tasks.
- daemonThread(Runnable, Class<?>, String) - Static method in class com.netflix.hollow.core.util.Threads
-
- daemonThread(Runnable, Class<?>, String, int) - Static method in class com.netflix.hollow.core.util.Threads
-
- daemonThread(Runnable, String, Class<?>, String) - Static method in class com.netflix.hollow.core.util.Threads
-
- daemonThread(Runnable, String) - Static method in class com.netflix.hollow.core.util.Threads
-
- dataAccess - Variable in class com.netflix.hollow.core.read.dataaccess.proxy.HollowTypeProxyDataAccess
-
- dataAccess - Variable in class com.netflix.hollow.tools.history.HollowHistoricalTypeDataAccess
-
- dataInitialized(HollowAPI, HollowReadStateEngine, long) - Method in interface com.netflix.hollow.api.client.HollowUpdateListener
-
Deprecated.
Called whenever a state engine is initialized (either because the first snapshot was applied, or because a
broken delta chain was found and a double snapshot occurred).
- dataModel - Variable in class com.netflix.hollow.api.producer.HollowIncrementalProducer.Builder
-
Deprecated.
- DataModelInitializationListener - Interface in com.netflix.hollow.api.producer.listener
-
A listener of data model initialization events.
- dataset - Variable in class com.netflix.hollow.api.codegen.AbstractHollowAPIGeneratorBuilder
-
- dataset - Variable in class com.netflix.hollow.api.codegen.HollowAPIGenerator
-
- dataset - Variable in class com.netflix.hollow.api.codegen.HollowConsumerJavaFileGenerator
-
- dataUpdated(HollowAPI, HollowReadStateEngine, long) - Method in interface com.netflix.hollow.api.client.HollowUpdateListener
-
Deprecated.
Called whenever a state engine's data is updated.
- decodeInt(int) - Static method in class com.netflix.hollow.core.memory.encoding.ZigZag
-
- decodeLong(long) - Static method in class com.netflix.hollow.core.memory.encoding.ZigZag
-
- decompress(InputStream) - Method in interface com.netflix.hollow.api.producer.HollowProducer.BlobCompressor
-
This method provides an opportunity to wrap the InputStream used to write the blob (e.g.
- DEFAULT_CONFIG - Static variable in interface com.netflix.hollow.api.client.HollowClientMemoryConfig
-
Deprecated.
- DEFAULT_CONFIG - Static variable in interface com.netflix.hollow.api.consumer.HollowConsumer.DoubleSnapshotConfig
-
- DEFAULT_CONFIG - Static variable in interface com.netflix.hollow.api.consumer.HollowConsumer.ObjectLongevityConfig
-
- DEFAULT_DETECTOR - Static variable in interface com.netflix.hollow.api.consumer.HollowConsumer.ObjectLongevityDetector
-
- DEFAULT_DIRECTOR - Static variable in interface com.netflix.hollow.tools.combine.HollowCombinerCopyDirector
-
- DEFAULT_FACTORY - Static variable in interface com.netflix.hollow.api.client.HollowAPIFactory
-
- DEFAULT_INSTANCE - Static variable in class com.netflix.hollow.core.memory.pool.WastefulRecycler
-
- DEFAULT_LISTENER - Static variable in interface com.netflix.hollow.api.client.HollowUpdateListener
-
Deprecated.
- DEFAULT_LOG2_SEGMENT_SIZE_IN_BITS - Static variable in class com.netflix.hollow.core.memory.ThreadSafeBitSet
-
- DefaultHashCodeFinder - Class in com.netflix.hollow.core.util
-
Deprecated.
- DefaultHashCodeFinder(String...) - Constructor for class com.netflix.hollow.core.util.DefaultHashCodeFinder
-
Deprecated.
- DefaultMissingDataHandler - Class in com.netflix.hollow.core.read.missing
-
- DefaultMissingDataHandler() - Constructor for class com.netflix.hollow.core.read.missing.DefaultMissingDataHandler
-
- DefaultWatcher() - Constructor for class com.netflix.hollow.api.client.HollowAnnouncementWatcher.DefaultWatcher
-
Deprecated.
- DefaultWatcher(ExecutorService) - Constructor for class com.netflix.hollow.api.client.HollowAnnouncementWatcher.DefaultWatcher
-
Deprecated.
- DEFINED_HASH_CODES_HEADER_NAME - Static variable in interface com.netflix.hollow.core.util.HollowObjectHashCodeFinder
-
Deprecated.
- delegate - Variable in class com.netflix.hollow.api.objects.HollowList
-
- delegate - Variable in class com.netflix.hollow.api.objects.HollowMap
-
- delegate - Variable in class com.netflix.hollow.api.objects.HollowObject
-
- delegate - Variable in class com.netflix.hollow.api.objects.HollowSet
-
- delegate() - Method in class com.netflix.hollow.core.type.HBoolean
-
- delegate() - Method in class com.netflix.hollow.core.type.HDouble
-
- delegate() - Method in class com.netflix.hollow.core.type.HFloat
-
- delegate() - Method in class com.netflix.hollow.core.type.HInteger
-
- delegate() - Method in class com.netflix.hollow.core.type.HLong
-
- delegate() - Method in class com.netflix.hollow.core.type.HString
-
- delegateCachedClassname(HollowSchema) - Static method in class com.netflix.hollow.api.codegen.HollowCodeGenerationUtils
-
- delegateCachedImplName(String) - Static method in class com.netflix.hollow.api.codegen.HollowCodeGenerationUtils
-
- delegateInterfaceName(String) - Static method in class com.netflix.hollow.api.codegen.HollowCodeGenerationUtils
-
- delegateInterfaceName(HollowSchema) - Static method in class com.netflix.hollow.api.codegen.HollowCodeGenerationUtils
-
- delegateLookupClassname(HollowSchema) - Static method in class com.netflix.hollow.api.codegen.HollowCodeGenerationUtils
-
- delegateLookupImplName(String) - Static method in class com.netflix.hollow.api.codegen.HollowCodeGenerationUtils
-
- delete(Object) - Method in class com.netflix.hollow.api.producer.HollowIncrementalProducer
-
Deprecated.
- delete(Collection<Object>) - Method in class com.netflix.hollow.api.producer.HollowIncrementalProducer
-
Deprecated.
- delete(RecordPrimaryKey) - Method in class com.netflix.hollow.api.producer.HollowIncrementalProducer
-
Deprecated.
- delete(Object) - Method in interface com.netflix.hollow.api.producer.HollowProducer.Incremental.IncrementalWriteState
-
Deletes an object.
- delete(RecordPrimaryKey) - Method in interface com.netflix.hollow.api.producer.HollowProducer.Incremental.IncrementalWriteState
-
Deletes an object given its primary key value.
- DELETE_RECORD - Static variable in class com.netflix.hollow.api.producer.HollowIncrementalCyclePopulator
-
Deprecated.
- deleteInParallel(Collection<Object>) - Method in class com.netflix.hollow.api.producer.HollowIncrementalProducer
-
Deprecated.
- deltaApplied(HollowAPI, HollowReadStateEngine, long) - Method in class com.netflix.hollow.api.consumer.HollowConsumer.AbstractRefreshListener
-
- deltaApplied(HollowAPI, HollowReadStateEngine, long) - Method in interface com.netflix.hollow.api.consumer.HollowConsumer.TransitionAwareRefreshListener
-
This method is called whenever a delta is processed.
- deltaApplied(HollowAPI, HollowReadStateEngine, long) - Method in class com.netflix.hollow.api.consumer.metrics.AbstractRefreshMetricsListener
-
- deltaOccurred(long) - Method in class com.netflix.hollow.tools.history.HollowHistory
-
- deltaUpdateOccurred(HollowAPI, HollowReadStateEngine, long) - Method in class com.netflix.hollow.api.consumer.HollowConsumer.AbstractRefreshListener
-
- deltaUpdateOccurred(HollowAPI, HollowReadStateEngine, long) - Method in interface com.netflix.hollow.api.consumer.HollowConsumer.RefreshListener
-
This method is called whenever a live state engine's data is updated with a delta.
- deltaUpdateOccurred(HollowAPI, HollowReadStateEngine, long) - Method in class com.netflix.hollow.api.consumer.index.HashIndexSelect
-
- deltaUpdateOccurred(HollowAPI, HollowReadStateEngine, long) - Method in class com.netflix.hollow.api.consumer.index.UniqueKeyIndex
-
- deltaUpdateOccurred(HollowAPI, HollowReadStateEngine, long) - Method in class com.netflix.hollow.api.consumer.metrics.AbstractRefreshMetricsListener
-
- dependencyOrderedSchemaList(HollowDataset) - Static method in class com.netflix.hollow.core.schema.HollowSchemaSorter
-
Dependency types come before dependent types
- dependencyOrderedSchemaList(Collection<HollowSchema>) - Static method in class com.netflix.hollow.core.schema.HollowSchemaSorter
-
Dependency types come before dependent types
- destinationPath - Variable in class com.netflix.hollow.api.codegen.AbstractHollowAPIGeneratorBuilder
-
- destinationPath - Variable in class com.netflix.hollow.api.codegen.HollowAPIGenerator
-
- destinationVersion(long) - Method in class com.netflix.hollow.api.client.HollowUpdatePlan
-
- destinationVersion() - Method in class com.netflix.hollow.api.client.HollowUpdatePlan
-
- destroy() - Method in class com.netflix.hollow.core.index.GrowingSegmentedLongArray
-
- destroy() - Method in class com.netflix.hollow.core.index.HollowPrimaryKeyIndex
-
- destroy() - Method in class com.netflix.hollow.core.index.MultiLinkedElementArray
-
- destroy() - Method in class com.netflix.hollow.core.memory.encoding.FixedLengthMultipleOccurrenceElementArray
-
A destructor function - call to free up the underlying memory.
- destroy() - Method in class com.netflix.hollow.core.memory.encoding.GapEncodedVariableLengthIntegerReader
-
- destroy(FixedLengthData, ArraySegmentRecycler) - Static method in class com.netflix.hollow.core.memory.FixedLengthDataFactory
-
- destroy() - Method in class com.netflix.hollow.core.memory.SegmentedByteArray
-
- destroy(ArraySegmentRecycler) - Method in class com.netflix.hollow.core.memory.SegmentedLongArray
-
- destroy(VariableLengthData) - Static method in class com.netflix.hollow.core.memory.VariableLengthDataFactory
-
- destroy() - Method in class com.netflix.hollow.core.read.engine.list.HollowListTypeDataElements
-
- destroy() - Method in class com.netflix.hollow.core.read.engine.map.HollowMapTypeDataElements
-
- destroy() - Method in class com.netflix.hollow.core.read.engine.object.HollowObjectTypeDataElements
-
- destroy() - Method in class com.netflix.hollow.core.read.engine.set.HollowSetTypeDataElements
-
- detach() - Method in class com.netflix.hollow.api.objects.provider.HollowObjectCacheProvider
-
- detachCaches() - Method in class com.netflix.hollow.api.custom.HollowAPI
-
- detachFromDataRefresh() - Method in class com.netflix.hollow.api.consumer.index.AbstractHollowHashIndex
-
Deprecated.
- detachFromDataRefresh() - Method in class com.netflix.hollow.api.consumer.index.AbstractHollowUniqueKeyIndex
-
- detachFromDeltaUpdates() - Method in class com.netflix.hollow.core.index.HollowHashIndex
-
Once called, this HollowHashIndex will no longer be kept up-to-date when deltas are applied to the indexed state engine.
- detachFromDeltaUpdates() - Method in class com.netflix.hollow.core.index.HollowPrefixIndex
-
Stop delta updates for this index.
- detachFromDeltaUpdates() - Method in class com.netflix.hollow.core.index.HollowPrimaryKeyIndex
-
Once called, this HollowPrimaryKeyIndex will no longer be kept up-to-date when deltas are applied to the indexed state engine.
- detachFromDeltaUpdates() - Method in class com.netflix.hollow.core.index.HollowSparseIntegerSet
-
Stop delta updates for this index.
- detail(String, Object) - Method in class com.netflix.hollow.api.producer.validation.ValidationResult.ValidationResultBuilder
-
Sets a detail.
- DiffEqualityCollectionMapper - Class in com.netflix.hollow.tools.diff.exact.mapper
-
Not intended for external consumption.
- DiffEqualityCollectionMapper(DiffEqualityMapping, HollowCollectionTypeReadState, HollowCollectionTypeReadState, boolean) - Constructor for class com.netflix.hollow.tools.diff.exact.mapper.DiffEqualityCollectionMapper
-
- DiffEqualityCollectionMapper(DiffEqualityMapping, HollowCollectionTypeReadState, HollowCollectionTypeReadState, boolean, boolean) - Constructor for class com.netflix.hollow.tools.diff.exact.mapper.DiffEqualityCollectionMapper
-
- DiffEqualityMapMapper - Class in com.netflix.hollow.tools.diff.exact.mapper
-
Not intended for external consumption.
- DiffEqualityMapMapper(DiffEqualityMapping, HollowMapTypeReadState, HollowMapTypeReadState, boolean) - Constructor for class com.netflix.hollow.tools.diff.exact.mapper.DiffEqualityMapMapper
-
- DiffEqualityMapping - Class in com.netflix.hollow.tools.diff.exact
-
The
HollowDiff
uses this class to expedite diff processing -- this class determines pairs of records which are exactly equal.
- DiffEqualityMapping(HollowReadStateEngine, HollowReadStateEngine) - Constructor for class com.netflix.hollow.tools.diff.exact.DiffEqualityMapping
-
- DiffEqualityMapping(HollowReadStateEngine, HollowReadStateEngine, boolean, boolean) - Constructor for class com.netflix.hollow.tools.diff.exact.DiffEqualityMapping
-
- DiffEqualityMappingOrdinalRemapper - Class in com.netflix.hollow.tools.history
-
- DiffEqualityObjectMapper - Class in com.netflix.hollow.tools.diff.exact.mapper
-
Not intended for external consumption.
- DiffEqualityObjectMapper(DiffEqualityMapping, HollowObjectTypeReadState, HollowObjectTypeReadState, boolean) - Constructor for class com.netflix.hollow.tools.diff.exact.mapper.DiffEqualityObjectMapper
-
- DiffEqualityOrderedListMapper - Class in com.netflix.hollow.tools.diff.exact.mapper
-
Not intended for external consumption.
- DiffEqualityOrderedListMapper(DiffEqualityMapping, HollowListTypeReadState, HollowListTypeReadState, boolean) - Constructor for class com.netflix.hollow.tools.diff.exact.mapper.DiffEqualityOrderedListMapper
-
- DiffEqualityTypeMapper - Class in com.netflix.hollow.tools.diff.exact.mapper
-
Not intended for external consumption.
- DiffEqualityTypeMapper(HollowTypeReadState, HollowTypeReadState, boolean) - Constructor for class com.netflix.hollow.tools.diff.exact.mapper.DiffEqualityTypeMapper
-
- DiffEqualityTypeMapper.EqualityDeterminer - Interface in com.netflix.hollow.tools.diff.exact.mapper
-
- DiffEqualOrdinalFilter - Class in com.netflix.hollow.tools.diff.exact
-
Not intended for external consumption.
- DiffEqualOrdinalFilter(DiffEqualOrdinalMap) - Constructor for class com.netflix.hollow.tools.diff.exact.DiffEqualOrdinalFilter
-
- DiffEqualOrdinalMap - Class in com.netflix.hollow.tools.diff.exact
-
Not intended for external consumption.
- DiffEqualOrdinalMap(int) - Constructor for class com.netflix.hollow.tools.diff.exact.DiffEqualOrdinalMap
-
- DiffEqualOrdinalMap.EmptyMatchIterator - Class in com.netflix.hollow.tools.diff.exact
-
- DiffEqualOrdinalMap.MatchIterator - Interface in com.netflix.hollow.tools.diff.exact
-
- DiffEqualOrdinalMap.OrdinalIdentityTranslator - Interface in com.netflix.hollow.tools.diff.exact
-
- DiffEqualOrdinalMap.PivotedMatchIterator - Class in com.netflix.hollow.tools.diff.exact
-
- DiffEqualOrdinalMap.SingleMatchIterator - Class in com.netflix.hollow.tools.diff.exact
-
- disable() - Method in class com.netflix.hollow.api.producer.enforcer.AbstractSingleProducerEnforcer
-
- disable() - Method in interface com.netflix.hollow.api.producer.enforcer.SingleProducerEnforcer
-
Relinquish the primary producer status.
- disableDataAccess() - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowProxyDataAccess
-
- DisabledSamplingDirector - Class in com.netflix.hollow.api.sampling
-
- discard(Object) - Method in class com.netflix.hollow.api.producer.HollowIncrementalProducer
-
Deprecated.
- discard(Collection<Object>) - Method in class com.netflix.hollow.api.producer.HollowIncrementalProducer
-
Deprecated.
- discard(RecordPrimaryKey) - Method in class com.netflix.hollow.api.producer.HollowIncrementalProducer
-
Deprecated.
- discardDelta(HollowBlobInput, int) - Static method in class com.netflix.hollow.core.read.engine.list.HollowListTypeReadState
-
- discardDelta(HollowBlobInput, int) - Static method in class com.netflix.hollow.core.read.engine.map.HollowMapTypeReadState
-
- discardDelta(HollowBlobInput, HollowObjectSchema, int) - Static method in class com.netflix.hollow.core.read.engine.object.HollowObjectTypeReadState
-
- discardDelta(HollowBlobInput, int) - Static method in class com.netflix.hollow.core.read.engine.set.HollowSetTypeReadState
-
- discardEncodedDeltaOrdinals(HollowBlobInput) - Static method in class com.netflix.hollow.core.memory.encoding.GapEncodedVariableLengthIntegerReader
-
- discardFrom(HollowBlobInput) - Static method in interface com.netflix.hollow.core.memory.FixedLengthData
-
Discard fixed length data from input.
- discardInParallel(Collection<Object>) - Method in class com.netflix.hollow.api.producer.HollowIncrementalProducer
-
Deprecated.
- discardOrdinals(HollowBlobInput) - Static method in class com.netflix.hollow.core.read.engine.SnapshotPopulatedOrdinalsReader
-
- discardSnapshot(HollowBlobInput, int) - Static method in class com.netflix.hollow.core.read.engine.list.HollowListTypeReadState
-
- discardSnapshot(HollowBlobInput, int) - Static method in class com.netflix.hollow.core.read.engine.map.HollowMapTypeReadState
-
- discardSnapshot(HollowBlobInput, HollowObjectSchema, int) - Static method in class com.netflix.hollow.core.read.engine.object.HollowObjectTypeReadState
-
- discardSnapshot(HollowBlobInput, int) - Static method in class com.netflix.hollow.core.read.engine.set.HollowSetTypeReadState
-
- discardType(HollowBlobInput, int, boolean) - Static method in class com.netflix.hollow.core.read.engine.list.HollowListTypeReadState
-
- discardType(HollowBlobInput, int, boolean) - Static method in class com.netflix.hollow.core.read.engine.map.HollowMapTypeReadState
-
- discardType(HollowBlobInput, HollowObjectSchema, int, boolean) - Static method in class com.netflix.hollow.core.read.engine.object.HollowObjectTypeReadState
-
- discardType(HollowBlobInput, int, boolean) - Static method in class com.netflix.hollow.core.read.engine.set.HollowSetTypeReadState
-
- displayString(HollowObjectTypeDataAccess, int, int) - Static method in class com.netflix.hollow.core.read.HollowReadFieldUtils
-
- DO_NOTHING - Static variable in class com.netflix.hollow.api.client.HollowUpdatePlan
-
- doesIncludeType(String) - Method in class com.netflix.hollow.core.read.filter.HollowFilterConfig
-
Deprecated.
- doNotUseDefaultHashKeys() - Method in class com.netflix.hollow.core.write.objectmapper.HollowObjectMapper
-
- DoubleDataAccessor - Class in com.netflix.hollow.core.type.accessor
-
- DoubleDataAccessor(HollowConsumer) - Constructor for class com.netflix.hollow.core.type.accessor.DoubleDataAccessor
-
- DoubleDataAccessor(HollowReadStateEngine, HollowConsumerAPI.DoubleRetriever) - Constructor for class com.netflix.hollow.core.type.accessor.DoubleDataAccessor
-
- DoubleDelegate - Interface in com.netflix.hollow.core.type.delegate
-
- DoubleDelegateCachedImpl - Class in com.netflix.hollow.core.type.delegate
-
- DoubleDelegateCachedImpl(DoubleTypeAPI, int) - Constructor for class com.netflix.hollow.core.type.delegate.DoubleDelegateCachedImpl
-
- DoubleDelegateLookupImpl - Class in com.netflix.hollow.core.type.delegate
-
- DoubleDelegateLookupImpl(DoubleTypeAPI) - Constructor for class com.netflix.hollow.core.type.delegate.DoubleDelegateLookupImpl
-
- doubleHashCode(double) - Static method in class com.netflix.hollow.core.read.HollowReadFieldUtils
-
- DoubleHollowFactory - Class in com.netflix.hollow.core.type
-
- DoubleHollowFactory() - Constructor for class com.netflix.hollow.core.type.DoubleHollowFactory
-
- doubleSnapshotConfig - Variable in class com.netflix.hollow.api.consumer.HollowConsumer.Builder
-
- doubleSnapshotOccurred(HollowReadStateEngine, long) - Method in class com.netflix.hollow.tools.history.HollowHistory
-
Call this method after each time a double snapshot occurs.
- DoubleTypeAPI - Class in com.netflix.hollow.core.type
-
- DoubleTypeAPI(HollowAPI, HollowObjectTypeDataAccess) - Constructor for class com.netflix.hollow.core.type.DoubleTypeAPI
-
- dropDataAutomatically() - Method in class com.netflix.hollow.api.client.HollowClientMemoryConfig.SpecifiedConfig
-
Deprecated.
- dropDataAutomatically() - Method in interface com.netflix.hollow.api.consumer.HollowConsumer.ObjectLongevityConfig
-
- dump(FlatRecord) - Method in class com.netflix.hollow.core.write.objectmapper.flatrecords.FlatRecordDumper
-
- duplicate() - Method in class com.netflix.hollow.core.memory.encoding.BlobByteBuffer
-
Returns a view on the current BlobByteBuffer
as a new BlobByteBuffer
.
- DuplicateDataDetectionValidator - Class in com.netflix.hollow.api.producer.validation
-
A validator that fails if two or more records of the same type are present and they have the same primary key.
- DuplicateDataDetectionValidator(Class<?>) - Constructor for class com.netflix.hollow.api.producer.validation.DuplicateDataDetectionValidator
-
Creates a validator to detect duplicate records of the type that corresponds to the given data type class
annotated with
HollowPrimaryKey
.
- DuplicateDataDetectionValidator(String) - Constructor for class com.netflix.hollow.api.producer.validation.DuplicateDataDetectionValidator
-
Creates a validator to detect duplicate records of the type that corresponds to the given data type name.
- DuplicateDataDetectionValidator(String, String[]) - Constructor for class com.netflix.hollow.api.producer.validation.DuplicateDataDetectionValidator
-
Creates a validator to detect duplicate records of the type that corresponds to the given data type name
with a primary key composed from the given field paths.
- failed(String) - Method in class com.netflix.hollow.api.producer.validation.ValidationResult.ValidationResultBuilder
-
Builds a result that has
failed
with a message.
- failed() - Method in class com.netflix.hollow.api.producer.validation.ValidationStatus
-
Returns true if one or more validation results failed or was erroneous, otherwise false if all results
passed.
- FailedTransitionTracker - Class in com.netflix.hollow.api.client
-
Tracks the blobs which failed to be successfully applied by a HollowClient.
- FailedTransitionTracker() - Constructor for class com.netflix.hollow.api.client.FailedTransitionTracker
-
- fieldHashCode(HollowObjectTypeDataAccess, int, int) - Static method in class com.netflix.hollow.core.read.HollowReadFieldUtils
-
Hash a field in an OBJECT record.
- fieldIndex - Variable in class com.netflix.hollow.api.custom.HollowObjectTypeAPI
-
- fieldNames - Variable in class com.netflix.hollow.api.custom.HollowObjectTypeAPI
-
- FieldPath - Annotation Type in com.netflix.hollow.api.consumer.index
-
A field path associated with a field or method declaration whose type or
return type respectively is associated resolution of the field path.
- FieldPaths - Class in com.netflix.hollow.core.index
-
Functionality for processing field paths.
- FieldPaths() - Constructor for class com.netflix.hollow.core.index.FieldPaths
-
- FieldPaths.FieldPath<T extends FieldPaths.FieldSegment> - Class in com.netflix.hollow.core.index
-
A structured representation field path containing field segments.
- FieldPaths.FieldSegment - Class in com.netflix.hollow.core.index
-
A structured representation of field segment.
- FieldPaths.ObjectFieldSegment - Class in com.netflix.hollow.core.index
-
A structured representation of field segment corresponding to a field in an object schema.
- fieldsAreEqual(HollowObjectTypeDataAccess, int, int, HollowObjectTypeDataAccess, int, int) - Static method in class com.netflix.hollow.core.read.HollowReadFieldUtils
-
Determine whether two OBJECT field records are exactly equal.
- FieldStatistics - Class in com.netflix.hollow.core.write
-
- FieldStatistics(HollowObjectSchema) - Constructor for class com.netflix.hollow.core.write.FieldStatistics
-
- fieldValueEquals(HollowObjectTypeDataAccess, int, int, Object) - Static method in class com.netflix.hollow.core.read.HollowReadFieldUtils
-
- fieldValueObject(HollowObjectTypeDataAccess, int, int) - Static method in class com.netflix.hollow.core.read.HollowReadFieldUtils
-
- fill(long) - Method in class com.netflix.hollow.core.memory.SegmentedLongArray
-
- filter(IntList, IntList) - Method in class com.netflix.hollow.tools.diff.exact.DiffEqualOrdinalFilter
-
- filter(boolean, InputStream, OutputStream...) - Method in class com.netflix.hollow.tools.filter.FilteredHollowBlobWriter
-
- filterConfig - Variable in class com.netflix.hollow.api.consumer.HollowConsumer.Builder
-
- filterDelta(InputStream, OutputStream...) - Method in class com.netflix.hollow.tools.filter.FilteredHollowBlobWriter
-
Filter a delta (or reversedelta), provided via the InputStream, to each of the OutputStreams.
- FilteredHollowBlobWriter - Class in com.netflix.hollow.tools.filter
-
The FilteredHollowBlobWriter can be used to pre-filter data from serialized blobs before disseminating to
specific clients.
- FilteredHollowBlobWriter(HollowFilterConfig...) - Constructor for class com.netflix.hollow.tools.filter.FilteredHollowBlobWriter
-
A FilteredHollowBlobWriter should be configured with one or more configs.
- filterSchema(HollowFilterConfig) - Method in class com.netflix.hollow.core.schema.HollowObjectSchema
-
- filterSchema(TypeFilter) - Method in class com.netflix.hollow.core.schema.HollowObjectSchema
-
- filterSnapshot(InputStream, OutputStream...) - Method in class com.netflix.hollow.tools.filter.FilteredHollowBlobWriter
-
Filter a snapshot, provided via the InputStream, to each of the OutputStreams.
- finalize() - Method in class com.netflix.hollow.api.consumer.fs.HollowFilesystemAnnouncementWatcher
-
- findAddedOrdinal(int) - Method in class com.netflix.hollow.tools.history.keyindex.HollowHistoricalStateTypeKeyOrdinalMapping
-
- findCommonSchema(HollowObjectSchema) - Method in class com.netflix.hollow.core.schema.HollowObjectSchema
-
- findElement(int, Object...) - Method in class com.netflix.hollow.api.custom.HollowSetTypeAPI
-
- findElement(HollowSet<T>, int, Object...) - Method in class com.netflix.hollow.api.objects.delegate.HollowSetCachedDelegate
-
- findElement(HollowSet<T>, int, Object...) - Method in interface com.netflix.hollow.api.objects.delegate.HollowSetDelegate
-
- findElement(HollowSet<T>, int, Object...) - Method in class com.netflix.hollow.api.objects.delegate.HollowSetLookupDelegate
-
- findElement(Object...) - Method in class com.netflix.hollow.api.objects.HollowSet
-
Find an element with the specified hash key.
- findElement(int, Object...) - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowSetDisabledDataAccess
-
- findElement(int, Object...) - Method in interface com.netflix.hollow.core.read.dataaccess.HollowSetTypeDataAccess
-
Returns The matching ordinal of the element from the set at the specified ordinal which matches the provided hash key.
- findElement(int, Object...) - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowSetMissingDataAccess
-
- findElement(int, Object...) - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowSetProxyDataAccess
-
- findElement(int, Object...) - Method in class com.netflix.hollow.core.read.engine.set.HollowSetTypeReadState
-
- findElement(int, Object...) - Method in class com.netflix.hollow.tools.history.HollowHistoricalSetDataAccess
-
- findEntry(int, Object...) - Method in class com.netflix.hollow.api.custom.HollowMapTypeAPI
-
- findEntry(HollowMap<K, V>, int, Object...) - Method in class com.netflix.hollow.api.objects.delegate.HollowMapCachedDelegate
-
- findEntry(HollowMap<K, V>, int, Object...) - Method in interface com.netflix.hollow.api.objects.delegate.HollowMapDelegate
-
- findEntry(HollowMap<K, V>, int, Object...) - Method in class com.netflix.hollow.api.objects.delegate.HollowMapLookupDelegate
-
- findEntry(Object...) - Method in class com.netflix.hollow.api.objects.HollowMap
-
- findEntry(int, Object...) - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowMapDisabledDataAccess
-
- findEntry(int, Object...) - Method in interface com.netflix.hollow.core.read.dataaccess.HollowMapTypeDataAccess
-
- findEntry(int, Object...) - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowMapMissingDataAccess
-
- findEntry(int, Object...) - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowMapProxyDataAccess
-
- findEntry(int, Object...) - Method in class com.netflix.hollow.core.read.engine.map.HollowMapTypeReadState
-
- findEntry(int, Object...) - Method in class com.netflix.hollow.tools.history.HollowHistoricalMapDataAccess
-
- findKey(int, Object...) - Method in class com.netflix.hollow.api.custom.HollowMapTypeAPI
-
- findKey(HollowMap<K, V>, int, Object...) - Method in class com.netflix.hollow.api.objects.delegate.HollowMapCachedDelegate
-
- findKey(HollowMap<K, V>, int, Object...) - Method in interface com.netflix.hollow.api.objects.delegate.HollowMapDelegate
-
- findKey(HollowMap<K, V>, int, Object...) - Method in class com.netflix.hollow.api.objects.delegate.HollowMapLookupDelegate
-
- findKey(Object...) - Method in class com.netflix.hollow.api.objects.HollowMap
-
- findKey(int, Object...) - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowMapDisabledDataAccess
-
- findKey(int, Object...) - Method in interface com.netflix.hollow.core.read.dataaccess.HollowMapTypeDataAccess
-
- findKey(int, Object...) - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowMapMissingDataAccess
-
- findKey(int, Object...) - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowMapProxyDataAccess
-
- findKey(int, Object...) - Method in class com.netflix.hollow.core.read.engine.map.HollowMapTypeReadState
-
- findKey(int, Object...) - Method in class com.netflix.hollow.tools.history.HollowHistoricalMapDataAccess
-
- findKeyIndexOrdinal(HollowObjectTypeReadState, int) - Method in class com.netflix.hollow.tools.history.keyindex.HollowHistoryTypeKeyIndex
-
- findKeysWithPrefix(String) - Method in class com.netflix.hollow.core.index.HollowPrefixIndex
-
Query the index to find all the ordinals that match the given prefix.
- findMatch(Object...) - Method in interface com.netflix.hollow.api.consumer.index.HollowUniqueKeyIndex
-
- findMatch(Q) - Method in class com.netflix.hollow.api.consumer.index.UniqueKeyIndex
-
Finds the unique object, an instance of the unique type, for a given key.
- findMatches(Q) - Method in class com.netflix.hollow.api.consumer.index.HashIndexSelect
-
Finds matches for a given query.
- findMatches(Object...) - Method in class com.netflix.hollow.core.index.HollowHashIndex
-
Query the index.
- findMatchingRecords(String, String) - Method in class com.netflix.hollow.tools.query.HollowFieldMatchQuery
-
Match any records which include a field with the provided fieldName and value.
- findMatchingRecords(String, String, String) - Method in class com.netflix.hollow.tools.query.HollowFieldMatchQuery
-
Match any records of the specified type, which have the specified field set to the specified value.
- findPrimaryKeyIndex(HollowTypeReadState) - Static method in class com.netflix.hollow.tools.util.SearchUtils
-
Returns primary key index for a given type if it exists.
- findRemovedOrdinal(int) - Method in class com.netflix.hollow.tools.history.keyindex.HollowHistoricalStateTypeKeyOrdinalMapping
-
- findUnionSchema(HollowObjectSchema) - Method in class com.netflix.hollow.core.schema.HollowObjectSchema
-
- findValue(int, Object...) - Method in class com.netflix.hollow.api.custom.HollowMapTypeAPI
-
- findValue(HollowMap<K, V>, int, Object...) - Method in class com.netflix.hollow.api.objects.delegate.HollowMapCachedDelegate
-
- findValue(HollowMap<K, V>, int, Object...) - Method in interface com.netflix.hollow.api.objects.delegate.HollowMapDelegate
-
- findValue(HollowMap<K, V>, int, Object...) - Method in class com.netflix.hollow.api.objects.delegate.HollowMapLookupDelegate
-
- findValue(Object...) - Method in class com.netflix.hollow.api.objects.HollowMap
-
- findValue(int, Object...) - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowMapDisabledDataAccess
-
- findValue(int, Object...) - Method in interface com.netflix.hollow.core.read.dataaccess.HollowMapTypeDataAccess
-
- findValue(int, Object...) - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowMapMissingDataAccess
-
- findValue(int, Object...) - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowMapProxyDataAccess
-
- findValue(int, Object...) - Method in class com.netflix.hollow.core.read.engine.map.HollowMapTypeReadState
-
- findValue(int, Object...) - Method in class com.netflix.hollow.tools.history.HollowHistoricalMapDataAccess
-
- findVarLengthFieldHashCode(int, int) - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowObjectDisabledDataAccess
-
- findVarLengthFieldHashCode(int, int) - Method in interface com.netflix.hollow.core.read.dataaccess.HollowObjectTypeDataAccess
-
- findVarLengthFieldHashCode(int, int) - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowObjectMissingDataAccess
-
- findVarLengthFieldHashCode(int, int) - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowObjectProxyDataAccess
-
- findVarLengthFieldHashCode(int, int) - Method in class com.netflix.hollow.core.read.engine.object.HollowObjectTypeReadState
-
- findVarLengthFieldHashCode(int, int) - Method in class com.netflix.hollow.tools.history.HollowHistoricalObjectDataAccess
-
- finish() - Method in class com.netflix.hollow.tools.history.keyindex.HollowHistoricalStateTypeKeyOrdinalMapping
-
- fire(Class<T>, Consumer<? super T>) - Method in class com.netflix.hollow.api.common.Listeners
-
- fireStream(Stream<T>, Consumer<? super T>) - Method in class com.netflix.hollow.api.common.Listeners
-
- FixedLengthData - Interface in com.netflix.hollow.core.memory
-
Each record in Hollow begins with a fixed-length number of bits.
- FixedLengthDataFactory - Class in com.netflix.hollow.core.memory
-
- FixedLengthDataFactory() - Constructor for class com.netflix.hollow.core.memory.FixedLengthDataFactory
-
- FixedLengthElementArray - Class in com.netflix.hollow.core.memory.encoding
-
Note that for performance reasons, this class makes use of sun.misc.Unsafe
to perform
unaligned memory reads.
- FixedLengthElementArray(ArraySegmentRecycler, long) - Constructor for class com.netflix.hollow.core.memory.encoding.FixedLengthElementArray
-
- FixedLengthMultipleOccurrenceElementArray - Class in com.netflix.hollow.core.memory.encoding
-
This class stores multiple instances of a fixed bit width element in a list of nodes.
- FixedLengthMultipleOccurrenceElementArray(ArraySegmentRecycler, long, int, int) - Constructor for class com.netflix.hollow.core.memory.encoding.FixedLengthMultipleOccurrenceElementArray
-
- flatRecBuffer() - Method in class com.netflix.hollow.core.write.objectmapper.HollowTypeMapper
-
- FlatRecord - Class in com.netflix.hollow.core.write.objectmapper.flatrecords
-
Warning: Experimental.
- FlatRecord(ByteData, HollowSchemaIdentifierMapper) - Constructor for class com.netflix.hollow.core.write.objectmapper.flatrecords.FlatRecord
-
- FlatRecordDumper - Class in com.netflix.hollow.core.write.objectmapper.flatrecords
-
Warning: Experimental.
- FlatRecordDumper(HollowWriteStateEngine) - Constructor for class com.netflix.hollow.core.write.objectmapper.flatrecords.FlatRecordDumper
-
- FlatRecordExtractor - Class in com.netflix.hollow.core.write.objectmapper.flatrecords
-
Warning: Experimental.
- FlatRecordExtractor(HollowReadStateEngine, HollowSchemaIdentifierMapper) - Constructor for class com.netflix.hollow.core.write.objectmapper.flatrecords.FlatRecordExtractor
-
- FlatRecordWriter - Class in com.netflix.hollow.core.write.objectmapper.flatrecords
-
Warning: Experimental.
- FlatRecordWriter(HollowDataset, HollowSchemaIdentifierMapper) - Constructor for class com.netflix.hollow.core.write.objectmapper.flatrecords.FlatRecordWriter
-
- FloatDataAccessor - Class in com.netflix.hollow.core.type.accessor
-
- FloatDataAccessor(HollowConsumer) - Constructor for class com.netflix.hollow.core.type.accessor.FloatDataAccessor
-
- FloatDataAccessor(HollowReadStateEngine, HollowConsumerAPI.FloatRetriever) - Constructor for class com.netflix.hollow.core.type.accessor.FloatDataAccessor
-
- FloatDelegate - Interface in com.netflix.hollow.core.type.delegate
-
- FloatDelegateCachedImpl - Class in com.netflix.hollow.core.type.delegate
-
- FloatDelegateCachedImpl(FloatTypeAPI, int) - Constructor for class com.netflix.hollow.core.type.delegate.FloatDelegateCachedImpl
-
- FloatDelegateLookupImpl - Class in com.netflix.hollow.core.type.delegate
-
- FloatDelegateLookupImpl(FloatTypeAPI) - Constructor for class com.netflix.hollow.core.type.delegate.FloatDelegateLookupImpl
-
- floatHashCode(float) - Static method in class com.netflix.hollow.core.read.HollowReadFieldUtils
-
- FloatHollowFactory - Class in com.netflix.hollow.core.type
-
- FloatHollowFactory() - Constructor for class com.netflix.hollow.core.type.FloatHollowFactory
-
- FloatTypeAPI - Class in com.netflix.hollow.core.type
-
- FloatTypeAPI(HollowAPI, HollowObjectTypeDataAccess) - Constructor for class com.netflix.hollow.core.type.FloatTypeAPI
-
- flush() - Method in class com.netflix.hollow.api.producer.ProducerOptionalBlobPartConfig.OptionalBlobPartOutputStreams
-
- force() - Method in class com.netflix.hollow.api.producer.enforcer.AbstractSingleProducerEnforcer
-
- force() - Method in interface com.netflix.hollow.api.producer.enforcer.SingleProducerEnforcer
-
Force marking producer to enable processing cycles.
- forceDoubleSnapshotNextUpdate() - Method in class com.netflix.hollow.api.client.HollowAnnouncementWatcher
-
Deprecated.
Will force a double snapshot refresh on the next update.
- forceDoubleSnapshotNextUpdate() - Method in class com.netflix.hollow.api.client.HollowClient
-
Deprecated.
Will force a double snapshot refresh on the next update.
- forceDoubleSnapshotNextUpdate() - Method in class com.netflix.hollow.api.client.HollowClientUpdater
-
- forceDoubleSnapshotNextUpdate() - Method in class com.netflix.hollow.api.consumer.HollowConsumer
-
Will force a double snapshot refresh on the next update.
- forceDropData() - Method in class com.netflix.hollow.api.client.HollowClientMemoryConfig.SpecifiedConfig
-
Deprecated.
- forceDropData() - Method in interface com.netflix.hollow.api.consumer.HollowConsumer.ObjectLongevityConfig
-
- ForGeneratedAPI(Class<T>) - Constructor for class com.netflix.hollow.api.client.HollowAPIFactory.ForGeneratedAPI
-
- ForGeneratedAPI(Class<T>, String...) - Constructor for class com.netflix.hollow.api.client.HollowAPIFactory.ForGeneratedAPI
-
- forStateEngine(HollowReadStateEngine) - Static method in class com.netflix.hollow.tools.checksum.HollowChecksum
-
- forStateEngineWithCommonSchemas(HollowReadStateEngine, HollowReadStateEngine) - Static method in class com.netflix.hollow.tools.checksum.HollowChecksum
-
- foundReference(BitSet, int, BitSet, int) - Method in interface com.netflix.hollow.tools.traverse.TransitiveSetTraverser.TransitiveSetTraverserAction
-
- FreeOrdinalTracker - Class in com.netflix.hollow.core.memory
-
A stack of unused ordinals.
- FreeOrdinalTracker() - Constructor for class com.netflix.hollow.core.memory.FreeOrdinalTracker
-
- from(HollowConsumer, Class<T>) - Static method in class com.netflix.hollow.api.consumer.index.HashIndex
-
- from(HollowConsumer, Class<T>) - Static method in class com.netflix.hollow.api.consumer.index.UniqueKeyIndex
-
- from(ValidatorListener) - Static method in class com.netflix.hollow.api.producer.validation.ValidationResult
-
Initiates the building of a result from a validation listener.
- from(String) - Static method in class com.netflix.hollow.api.producer.validation.ValidationResult
-
Initiates the building of a result from a name.
- fromOrdinal() - Method in class com.netflix.hollow.tools.diff.exact.CombinedMatchPairResultsIterator
-
- fromRecordHashCode(int) - Method in class com.netflix.hollow.tools.diff.exact.mapper.DiffEqualityCollectionMapper
-
- fromRecordHashCode(int) - Method in class com.netflix.hollow.tools.diff.exact.mapper.DiffEqualityMapMapper
-
- fromRecordHashCode(int) - Method in class com.netflix.hollow.tools.diff.exact.mapper.DiffEqualityObjectMapper
-
- fromRecordHashCode(int) - Method in class com.netflix.hollow.tools.diff.exact.mapper.DiffEqualityTypeMapper
-
- fromState - Variable in class com.netflix.hollow.tools.diff.exact.mapper.DiffEqualityTypeMapper
-
- fromString(String) - Static method in class com.netflix.hollow.core.read.filter.HollowFilterConfig
-
Deprecated.
Parse a HollowFilterConfig from the specified String.
- fromTypeId(int) - Static method in enum com.netflix.hollow.core.schema.HollowSchema.SchemaType
-
- fromVersion - Variable in class com.netflix.hollow.api.producer.HollowProducer.Blob
-
- GapEncodedVariableLengthIntegerReader - Class in com.netflix.hollow.core.memory.encoding
-
- GapEncodedVariableLengthIntegerReader(SegmentedByteArray, int) - Constructor for class com.netflix.hollow.core.memory.encoding.GapEncodedVariableLengthIntegerReader
-
- genConstructors(StringBuilder) - Method in class com.netflix.hollow.api.codegen.api.HollowDataAccessorGenerator
-
- genConstructors(StringBuilder) - Method in class com.netflix.hollow.api.codegen.indexes.HollowUniqueKeyIndexGenerator
-
- genDeprecatedJavaDoc(StringBuilder) - Method in class com.netflix.hollow.api.codegen.indexes.HollowPrimaryKeyIndexGenerator
-
- genDeprecatedJavaDoc(StringBuilder) - Method in class com.netflix.hollow.api.codegen.indexes.HollowUniqueKeyIndexGenerator
-
- generate() - Method in class com.netflix.hollow.api.codegen.api.HollowDataAccessorGenerator
-
- generate() - Method in class com.netflix.hollow.api.codegen.api.TypeAPIListJavaGenerator
-
- generate() - Method in class com.netflix.hollow.api.codegen.api.TypeAPIMapJavaGenerator
-
- generate() - Method in class com.netflix.hollow.api.codegen.api.TypeAPIObjectJavaGenerator
-
- generate() - Method in class com.netflix.hollow.api.codegen.api.TypeAPISetJavaGenerator
-
- generate() - Method in class com.netflix.hollow.api.codegen.delegate.HollowObjectDelegateCachedImplGenerator
-
- generate() - Method in class com.netflix.hollow.api.codegen.delegate.HollowObjectDelegateInterfaceGenerator
-
- generate() - Method in class com.netflix.hollow.api.codegen.delegate.HollowObjectDelegateLookupImplGenerator
-
- generate() - Method in class com.netflix.hollow.api.codegen.HollowAPIClassJavaGenerator
-
- generate() - Method in class com.netflix.hollow.api.codegen.HollowAPIFactoryJavaGenerator
-
- generate() - Method in interface com.netflix.hollow.api.codegen.HollowJavaFileGenerator
-
- generate() - Method in class com.netflix.hollow.api.codegen.HollowPOJOClassGenerator
-
- generate() - Method in class com.netflix.hollow.api.codegen.indexes.HollowHashIndexGenerator
-
- generate() - Method in class com.netflix.hollow.api.codegen.indexes.HollowUniqueKeyIndexGenerator
-
- generate() - Method in class com.netflix.hollow.api.codegen.objects.HollowFactoryJavaGenerator
-
- generate() - Method in class com.netflix.hollow.api.codegen.objects.HollowListJavaGenerator
-
- generate() - Method in class com.netflix.hollow.api.codegen.objects.HollowMapJavaGenerator
-
- generate() - Method in class com.netflix.hollow.api.codegen.objects.HollowObjectJavaGenerator
-
- generate() - Method in class com.netflix.hollow.api.codegen.objects.HollowSetJavaGenerator
-
- generateAccessortMethodName(String, Class<?>) - Static method in class com.netflix.hollow.api.codegen.HollowCodeGenerationUtils
-
Rules: prepend "get" / "is" + upper case first char of field name
boolean/Boolean field:
- has a boolean prefix (@see
HollowCodeGenerationUtils.booleanMethodPrefixes
), just return it; otherwise, prepend "get" + upper case first char
boolean isPrimary - isPrimary()
boolean hasStreams - hasStreams()
boolean playable - getPlayable()
boolean value - getValue()
other field type: prepend "get" + upper case first char
String title - getTitle()
- generateBooleanAccessorMethodName(String, boolean) - Static method in class com.netflix.hollow.api.codegen.HollowCodeGenerationUtils
-
- generateFile(File, HollowJavaFileGenerator) - Method in class com.netflix.hollow.api.codegen.HollowAPIGenerator
-
- generateFiles(String) - Method in class com.netflix.hollow.api.codegen.HollowAPIGenerator
-
- generateFiles(File) - Method in class com.netflix.hollow.api.codegen.HollowAPIGenerator
-
- generateFiles(String) - Method in class com.netflix.hollow.api.codegen.HollowPOJOGenerator
-
- generateFiles(File) - Method in class com.netflix.hollow.api.codegen.HollowPOJOGenerator
-
- generateFilesForHollowSchemas(File) - Method in class com.netflix.hollow.api.codegen.HollowAPIGenerator
-
- generateFlatRecord() - Method in class com.netflix.hollow.core.write.objectmapper.flatrecords.FlatRecordWriter
-
- generateSourceFile(HollowJavaFileGenerator) - Method in class com.netflix.hollow.api.codegen.HollowAPIGenerator
-
- generateSourceFiles() - Method in class com.netflix.hollow.api.codegen.HollowAPIGenerator
-
Generate all files under destinationPath
- generateSourceFilesForHollowSchemas() - Method in class com.netflix.hollow.api.codegen.HollowAPIGenerator
-
Generate files based on dataset schemas under destinationPath
- GenericHollowList - Class in com.netflix.hollow.api.objects.generic
-
This is a generic handle to a LIST type record.
- GenericHollowList(HollowDataAccess, String, int) - Constructor for class com.netflix.hollow.api.objects.generic.GenericHollowList
-
- GenericHollowList(HollowListTypeDataAccess, int) - Constructor for class com.netflix.hollow.api.objects.generic.GenericHollowList
-
- GenericHollowList(HollowListDelegate<HollowRecord>, int) - Constructor for class com.netflix.hollow.api.objects.generic.GenericHollowList
-
- GenericHollowMap - Class in com.netflix.hollow.api.objects.generic
-
This is a generic handle to a MAP type record.
- GenericHollowMap(HollowDataAccess, String, int) - Constructor for class com.netflix.hollow.api.objects.generic.GenericHollowMap
-
- GenericHollowMap(HollowMapTypeDataAccess, int) - Constructor for class com.netflix.hollow.api.objects.generic.GenericHollowMap
-
- GenericHollowMap(HollowMapDelegate<HollowRecord, HollowRecord>, int) - Constructor for class com.netflix.hollow.api.objects.generic.GenericHollowMap
-
- GenericHollowObject - Class in com.netflix.hollow.api.objects.generic
-
This is a generic handle to an OBJECT type record.
- GenericHollowObject(HollowDataAccess, String, int) - Constructor for class com.netflix.hollow.api.objects.generic.GenericHollowObject
-
- GenericHollowObject(HollowObjectTypeDataAccess, int) - Constructor for class com.netflix.hollow.api.objects.generic.GenericHollowObject
-
- GenericHollowObject(HollowObjectDelegate, int) - Constructor for class com.netflix.hollow.api.objects.generic.GenericHollowObject
-
- GenericHollowRecordDataAccessor - Class in com.netflix.hollow.api.consumer.data
-
- GenericHollowRecordDataAccessor(HollowConsumer, String) - Constructor for class com.netflix.hollow.api.consumer.data.GenericHollowRecordDataAccessor
-
- GenericHollowRecordDataAccessor(HollowReadStateEngine, String) - Constructor for class com.netflix.hollow.api.consumer.data.GenericHollowRecordDataAccessor
-
- GenericHollowRecordDataAccessor(HollowReadStateEngine, String, String...) - Constructor for class com.netflix.hollow.api.consumer.data.GenericHollowRecordDataAccessor
-
- GenericHollowRecordDataAccessor(HollowReadStateEngine, String, PrimaryKey) - Constructor for class com.netflix.hollow.api.consumer.data.GenericHollowRecordDataAccessor
-
- GenericHollowRecordHelper - Class in com.netflix.hollow.api.objects.generic
-
Contains some useful methods for interacting with the Generic Hollow Objects API.
- GenericHollowRecordHelper() - Constructor for class com.netflix.hollow.api.objects.generic.GenericHollowRecordHelper
-
- GenericHollowSet - Class in com.netflix.hollow.api.objects.generic
-
This is a generic handle to a SET type record.
- GenericHollowSet(HollowDataAccess, String, int) - Constructor for class com.netflix.hollow.api.objects.generic.GenericHollowSet
-
- GenericHollowSet(HollowSetTypeDataAccess, int) - Constructor for class com.netflix.hollow.api.objects.generic.GenericHollowSet
-
- GenericHollowSet(HollowSetDelegate<HollowRecord>, int) - Constructor for class com.netflix.hollow.api.objects.generic.GenericHollowSet
-
- genFindMatchAPI(StringBuilder) - Method in class com.netflix.hollow.api.codegen.indexes.HollowPrimaryKeyIndexGenerator
-
- genFindMatchAPI(StringBuilder) - Method in class com.netflix.hollow.api.codegen.indexes.HollowUniqueKeyIndexGenerator
-
- genParameterizedConstructor(StringBuilder) - Method in class com.netflix.hollow.api.codegen.indexes.HollowUniqueKeyIndexGenerator
-
- genPublicAPIs(StringBuilder) - Method in class com.netflix.hollow.api.codegen.api.HollowDataAccessorGenerator
-
- genPublicAPIs(StringBuilder) - Method in class com.netflix.hollow.api.codegen.indexes.HollowUniqueKeyIndexGenerator
-
- genSimpleConstructor(StringBuilder) - Method in class com.netflix.hollow.api.codegen.indexes.HollowUniqueKeyIndexGenerator
-
- get(int, int) - Method in class com.netflix.hollow.api.custom.HollowMapTypeAPI
-
- get(int, int, int) - Method in class com.netflix.hollow.api.custom.HollowMapTypeAPI
-
- get(HollowList<T>, int, int) - Method in class com.netflix.hollow.api.objects.delegate.HollowListCachedDelegate
-
- get(HollowList<T>, int, int) - Method in interface com.netflix.hollow.api.objects.delegate.HollowListDelegate
-
- get(HollowList<T>, int, int) - Method in class com.netflix.hollow.api.objects.delegate.HollowListLookupDelegate
-
- get(HollowMap<K, V>, int, Object) - Method in class com.netflix.hollow.api.objects.delegate.HollowMapCachedDelegate
-
- get(HollowMap<K, V>, int, Object) - Method in interface com.netflix.hollow.api.objects.delegate.HollowMapDelegate
-
- get(HollowMap<K, V>, int, Object) - Method in class com.netflix.hollow.api.objects.delegate.HollowMapLookupDelegate
-
- get(int) - Method in class com.netflix.hollow.api.objects.HollowList
-
- get(Object) - Method in class com.netflix.hollow.api.objects.HollowMap
-
- get(long) - Method in class com.netflix.hollow.core.index.GrowingSegmentedLongArray
-
Get the value of the byte at the specified index.
- get(int) - Method in class com.netflix.hollow.core.index.HollowSparseIntegerSet
-
Check if the given value is contained in the set (or if the given value satisfies the predicate condition.)
- get(long) - Method in class com.netflix.hollow.core.memory.ArrayByteData
-
- get(ByteDataArray) - Method in class com.netflix.hollow.core.memory.ByteArrayOrdinalMap
-
Returns the ordinal for a previously added byte sequence.
- get(long) - Method in interface com.netflix.hollow.core.memory.ByteData
-
Get the value of the byte at the specified position.
- get(long) - Method in class com.netflix.hollow.core.memory.ByteDataArray
-
- get(long) - Method in class com.netflix.hollow.core.memory.EncodedByteBuffer
-
- get(HollowBlobInput, MemoryMode, ArraySegmentRecycler) - Static method in class com.netflix.hollow.core.memory.FixedLengthDataFactory
-
- get(long) - Method in class com.netflix.hollow.core.memory.SegmentedByteArray
-
Get the value of the byte at the specified index.
- get(long) - Method in class com.netflix.hollow.core.memory.SegmentedLongArray
-
Get the value of the long at the specified index.
- get(int) - Method in class com.netflix.hollow.core.memory.ThreadSafeBitSet
-
- get(MemoryMode, ArraySegmentRecycler) - Static method in class com.netflix.hollow.core.memory.VariableLengthDataFactory
-
- get(int, int) - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowMapDisabledDataAccess
-
- get(int, int, int) - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowMapDisabledDataAccess
-
- get(int, int) - Method in interface com.netflix.hollow.core.read.dataaccess.HollowMapTypeDataAccess
-
- get(int, int, int) - Method in interface com.netflix.hollow.core.read.dataaccess.HollowMapTypeDataAccess
-
- get(int, int) - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowMapMissingDataAccess
-
- get(int, int, int) - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowMapMissingDataAccess
-
- get(int, int) - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowMapProxyDataAccess
-
- get(int, int, int) - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowMapProxyDataAccess
-
- get(int, int) - Method in class com.netflix.hollow.core.read.engine.map.HollowMapTypeReadState
-
- get(int, int, int) - Method in class com.netflix.hollow.core.read.engine.map.HollowMapTypeReadState
-
- get(int) - Method in class com.netflix.hollow.core.util.IntList
-
- get(int) - Method in class com.netflix.hollow.core.util.IntMap
-
- get(int) - Method in class com.netflix.hollow.core.util.LongList
-
- get(int, int) - Method in class com.netflix.hollow.tools.history.HollowHistoricalMapDataAccess
-
- get(int, int, int) - Method in class com.netflix.hollow.tools.history.HollowHistoricalMapDataAccess
-
- getAccessSampleResults() - Method in class com.netflix.hollow.api.custom.HollowAPI
-
- getAccessSampleResults() - Method in class com.netflix.hollow.api.custom.HollowTypeAPI
-
- getAddedRecords() - Method in class com.netflix.hollow.api.consumer.data.AbstractHollowDataAccessor
-
- getAfter() - Method in class com.netflix.hollow.api.consumer.data.AbstractHollowDataAccessor.UpdatedRecord
-
- getAfterSchema() - Method in class com.netflix.hollow.tools.history.HollowHistoricalSchemaChange
-
- getAllHBoolean() - Method in interface com.netflix.hollow.api.consumer.HollowConsumerAPI.BooleanRetriever
-
- getAllHDouble() - Method in interface com.netflix.hollow.api.consumer.HollowConsumerAPI.DoubleRetriever
-
- getAllHFloat() - Method in interface com.netflix.hollow.api.consumer.HollowConsumerAPI.FloatRetriever
-
- getAllHInteger() - Method in interface com.netflix.hollow.api.consumer.HollowConsumerAPI.IntegerRetriever
-
- getAllHLong() - Method in interface com.netflix.hollow.api.consumer.HollowConsumerAPI.LongRetriever
-
- getAllHString() - Method in interface com.netflix.hollow.api.consumer.HollowConsumerAPI.StringRetriever
-
- getAllRecords() - Method in class com.netflix.hollow.api.consumer.data.AbstractHollowDataAccessor
-
- getAllTypes() - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowDisabledDataAccess
-
- getAllTypes() - Method in interface com.netflix.hollow.core.read.dataaccess.HollowDataAccess
-
- getAllTypes() - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowProxyDataAccess
-
- getAllTypes() - Method in class com.netflix.hollow.core.read.engine.HollowReadStateEngine
-
- getAllTypes() - Method in class com.netflix.hollow.tools.history.HollowHistoricalStateDataAccess
-
- getAnnouncementDurationMillis() - Method in class com.netflix.hollow.api.producer.metrics.AnnouncementMetrics
-
- getAPI() - Method in class com.netflix.hollow.api.client.HollowClient
-
Deprecated.
- getAPI() - Method in class com.netflix.hollow.api.client.HollowClientUpdater
-
- getAPI() - Method in class com.netflix.hollow.api.consumer.HollowConsumer
-
- getAPI(Class<T>) - Method in class com.netflix.hollow.api.consumer.HollowConsumer
-
- getAPI() - Method in class com.netflix.hollow.api.custom.HollowTypeAPI
-
- getApproximateHeapFootprintInBytes() - Method in class com.netflix.hollow.core.read.engine.HollowTypeReadState
-
- getApproximateHeapFootprintInBytes() - Method in class com.netflix.hollow.core.read.engine.list.HollowListTypeReadState
-
- getApproximateHeapFootprintInBytes() - Method in class com.netflix.hollow.core.read.engine.map.HollowMapTypeReadState
-
- getApproximateHeapFootprintInBytes() - Method in class com.netflix.hollow.core.read.engine.object.HollowObjectTypeReadState
-
- getApproximateHeapFootprintInBytes() - Method in class com.netflix.hollow.core.read.engine.set.HollowSetTypeReadState
-
- getApproximateHoleCostInBytes() - Method in class com.netflix.hollow.core.read.engine.HollowTypeReadState
-
- getApproximateHoleCostInBytes() - Method in class com.netflix.hollow.core.read.engine.list.HollowListTypeReadState
-
- getApproximateHoleCostInBytes() - Method in class com.netflix.hollow.core.read.engine.map.HollowMapTypeReadState
-
- getApproximateHoleCostInBytes() - Method in class com.netflix.hollow.core.read.engine.object.HollowObjectTypeReadState
-
- getApproximateHoleCostInBytes() - Method in class com.netflix.hollow.core.read.engine.set.HollowSetTypeReadState
-
- getAvailableTypes() - Method in exception com.netflix.hollow.api.error.SchemaNotFoundException
-
- getBaseDataAccess() - Method in class com.netflix.hollow.core.index.HollowHashIndexField
-
- getBaseIteratorFieldIdx() - Method in class com.netflix.hollow.core.index.HollowHashIndexField
-
- getBefore() - Method in class com.netflix.hollow.api.consumer.data.AbstractHollowDataAccessor.UpdatedRecord
-
- getBeforeSchema() - Method in class com.netflix.hollow.tools.history.HollowHistoricalSchemaChange
-
- getBeforeVersion() - Method in class com.netflix.hollow.api.consumer.metrics.ConsumerRefreshMetrics.UpdatePlanDetails
-
- getBitsPerMatchHashEntry() - Method in class com.netflix.hollow.core.index.HollowHashIndex.HollowHashIndexState
-
- getBitsPerMatchHashKey() - Method in class com.netflix.hollow.core.index.HollowHashIndex.HollowHashIndexState
-
- getBitsPerMatchHashKey() - Method in class com.netflix.hollow.core.index.HollowHashIndexBuilder
-
- getBitsPerSelectHashEntry() - Method in class com.netflix.hollow.core.index.HollowHashIndex.HollowHashIndexState
-
- getBitsPerSelectHashEntry() - Method in class com.netflix.hollow.core.index.HollowHashIndexBuilder
-
- getBitsPerSelectTablePointer() - Method in class com.netflix.hollow.core.index.HollowHashIndex.HollowHashIndexState
-
- getBitsPerSelectTableSize() - Method in class com.netflix.hollow.core.index.HollowHashIndex.HollowHashIndexState
-
- getBitsPerTraverserField() - Method in class com.netflix.hollow.core.index.HollowHashIndex.HollowHashIndexState
-
- getBitsPerTraverserField() - Method in class com.netflix.hollow.core.index.HollowHashIndexBuilder
-
- getBlob() - Method in class com.netflix.hollow.api.producer.HollowProducerListener.PublishStatus
-
An instance of Blob
has methods to get details on type of blob, size, from and to version.
- getBlobFormatVersion() - Method in class com.netflix.hollow.core.HollowBlobHeader
-
- getBlobType() - Method in class com.netflix.hollow.api.consumer.HollowConsumer.Blob
-
- getBoolean(int, String) - Method in class com.netflix.hollow.api.objects.delegate.HollowObjectAbstractDelegate
-
- getBoolean(int, String) - Method in interface com.netflix.hollow.api.objects.delegate.HollowObjectDelegate
-
- getBoolean(String) - Method in class com.netflix.hollow.api.objects.HollowObject
-
- getBooleanMethodPrefixes() - Static method in class com.netflix.hollow.api.codegen.HollowCodeGenerationUtils
-
- getBooleanValue() - Method in enum com.netflix.hollow.core.write.objectmapper.NullablePrimitiveBoolean
-
Deprecated.
- getBoxedFieldAccessSampler() - Method in class com.netflix.hollow.api.custom.HollowObjectTypeAPI
-
- getBoxedSampleResults() - Method in class com.netflix.hollow.api.custom.HollowAPI
-
- getBuffer() - Method in class com.netflix.hollow.core.read.HollowBlobInput
-
- getBuilder() - Method in class com.netflix.hollow.api.codegen.AbstractHollowAPIGeneratorBuilder
-
- getBuilder() - Method in class com.netflix.hollow.api.codegen.HollowAPIGenerator.Builder
-
- getByte(long) - Method in class com.netflix.hollow.core.memory.encoding.BlobByteBuffer
-
Reads the byte at the given index.
- getByteArray() - Method in interface com.netflix.hollow.core.memory.pool.ArraySegmentRecycler
-
- getByteArray() - Method in class com.netflix.hollow.core.memory.pool.RecyclingRecycler
-
- getByteArray() - Method in class com.netflix.hollow.core.memory.pool.WastefulRecycler
-
- getByteData() - Method in class com.netflix.hollow.core.memory.ByteArrayOrdinalMap
-
- getBytes(int, String) - Method in class com.netflix.hollow.api.objects.delegate.HollowObjectAbstractDelegate
-
- getBytes(int, String) - Method in interface com.netflix.hollow.api.objects.delegate.HollowObjectDelegate
-
- getBytes(String) - Method in class com.netflix.hollow.api.objects.HollowObject
-
- getCause() - Method in class com.netflix.hollow.api.producer.HollowProducerListener.ProducerStatus
-
Returns the failure cause if this status represents a HollowProducer
failure that was caused by an exception.
- getCause() - Method in class com.netflix.hollow.api.producer.HollowProducerListener.PublishStatus
-
- getCause() - Method in class com.netflix.hollow.api.producer.HollowProducerListener.RestoreStatus
-
Returns the failure cause if this status represents a HollowProducer
failure that was caused by an exception.
- getCause() - Method in class com.netflix.hollow.api.producer.IncrementalCycleListener.IncrementalCycleStatus
-
Deprecated.
Returns the failure cause if this status represents a HollowProducer
failure that was caused by an exception.
- getCause() - Method in class com.netflix.hollow.api.producer.Status
-
Returns the cause of producer action failure.
- getChecksum(HollowSchema) - Method in class com.netflix.hollow.core.read.engine.HollowTypeReadState
-
- getChild(StackTraceElement) - Method in class com.netflix.hollow.api.client.StackTraceRecorder.StackTraceNode
-
- getChildren() - Method in class com.netflix.hollow.api.client.StackTraceRecorder.StackTraceNode
-
- getClassName(HollowObjectSchema) - Method in class com.netflix.hollow.api.codegen.api.HollowDataAccessorGenerator
-
- getClassName() - Method in class com.netflix.hollow.api.codegen.HollowConsumerJavaFileGenerator
-
- getClassName() - Method in interface com.netflix.hollow.api.codegen.HollowJavaFileGenerator
-
- getClassName() - Method in class com.netflix.hollow.api.codegen.HollowPOJOClassGenerator
-
- getClassName(HollowObjectSchema) - Method in class com.netflix.hollow.api.codegen.indexes.HollowPrimaryKeyIndexGenerator
-
- getClassName(HollowObjectSchema) - Method in class com.netflix.hollow.api.codegen.indexes.HollowUniqueKeyIndexGenerator
-
- getClassName(HollowObjectSchema) - Method in class com.netflix.hollow.api.codegen.indexes.LegacyHollowPrimaryKeyIndexGenerator
-
- getClassPostfix() - Method in class com.netflix.hollow.api.codegen.CodeGeneratorConfig
-
- getClientToNotify() - Method in class com.netflix.hollow.api.client.HollowAnnouncementWatcher
-
Deprecated.
- getCombinedStateEngine() - Method in class com.netflix.hollow.tools.combine.HollowCombiner
-
- getCompleteFieldPathParts(HollowDataset, String, String) - Static method in class com.netflix.hollow.core.index.key.PrimaryKey
-
Returns a separated field path, which has been auto-expanded if necessary based on the provided primary key field
path.
- getConsecutiveFailures() - Method in class com.netflix.hollow.api.consumer.metrics.ConsumerRefreshMetrics
-
- getConsecutiveFailures() - Method in class com.netflix.hollow.api.producer.metrics.CycleMetrics
-
- getCount() - Method in class com.netflix.hollow.api.client.StackTraceRecorder.StackTraceNode
-
- getCurrentBucket() - Method in class com.netflix.hollow.core.read.iterator.HollowMapEntryOrdinalIteratorImpl
-
- getCurrentBucket() - Method in class com.netflix.hollow.core.read.iterator.HollowSetOrdinalIterator
-
- getCurrentRandomizedTag() - Method in class com.netflix.hollow.core.read.engine.HollowReadStateEngine
-
- getCurrentVersion() - Method in class com.netflix.hollow.api.metrics.HollowMetrics
-
- getCurrentVersionId() - Method in class com.netflix.hollow.api.client.HollowClient
-
Deprecated.
- getCurrentVersionId() - Method in class com.netflix.hollow.api.client.HollowClientUpdater
-
- getCurrentVersionId() - Method in class com.netflix.hollow.api.consumer.HollowConsumer
-
- getCycleDurationMillis() - Method in class com.netflix.hollow.api.producer.metrics.CycleMetrics
-
- getCycleFailed() - Method in class com.netflix.hollow.api.metrics.HollowProducerMetrics
-
- getCycleMetadata() - Method in class com.netflix.hollow.api.producer.IncrementalCycleListener.IncrementalCycleStatus
-
Deprecated.
- getCyclesCompleted() - Method in class com.netflix.hollow.api.metrics.HollowProducerMetrics
-
- getCyclesSucceeded() - Method in class com.netflix.hollow.api.metrics.HollowProducerMetrics
-
- getCycleStartTimestamp() - Method in class com.netflix.hollow.api.consumer.metrics.ConsumerRefreshMetrics
-
- getData(int) - Method in class com.netflix.hollow.api.consumer.data.AbstractHollowOrdinalIterable
-
- getDataAccess() - Method in class com.netflix.hollow.api.custom.HollowAPI
-
- getDataAccess() - Method in class com.netflix.hollow.api.custom.HollowObjectTypeAPI
-
- getDataAccess() - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowListDisabledDataAccess
-
- getDataAccess() - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowMapDisabledDataAccess
-
- getDataAccess() - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowObjectDisabledDataAccess
-
- getDataAccess() - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowSetDisabledDataAccess
-
- getDataAccess() - Method in interface com.netflix.hollow.core.read.dataaccess.HollowTypeDataAccess
-
- getDataAccess() - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowListMissingDataAccess
-
- getDataAccess() - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowMapMissingDataAccess
-
- getDataAccess() - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowObjectMissingDataAccess
-
- getDataAccess() - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowSetMissingDataAccess
-
- getDataAccess() - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowTypeProxyDataAccess
-
- getDataAccess() - Method in class com.netflix.hollow.core.read.engine.HollowTypeReadState
-
- getDataAccess() - Method in class com.netflix.hollow.tools.history.HollowHistoricalState
-
- getDataAccess() - Method in class com.netflix.hollow.tools.history.HollowHistoricalTypeDataAccess
-
- getDataSize() - Method in class com.netflix.hollow.core.memory.ByteArrayOrdinalMap
-
- getDataSizeBytes() - Method in class com.netflix.hollow.api.producer.metrics.AnnouncementMetrics
-
- getDefaultTypeName(Type) - Static method in class com.netflix.hollow.core.write.objectmapper.HollowTypeMapper
-
Calculates the type name from a given type.
- getDelegate() - Method in class com.netflix.hollow.api.objects.HollowList
-
- getDelegate() - Method in class com.netflix.hollow.api.objects.HollowMap
-
- getDelegate() - Method in class com.netflix.hollow.api.objects.HollowObject
-
- getDelegate() - Method in interface com.netflix.hollow.api.objects.HollowRecord
-
- getDelegate() - Method in class com.netflix.hollow.api.objects.HollowSet
-
- getDelegateLookupImpl() - Method in class com.netflix.hollow.core.type.BooleanTypeAPI
-
- getDelegateLookupImpl() - Method in class com.netflix.hollow.core.type.DoubleTypeAPI
-
- getDelegateLookupImpl() - Method in class com.netflix.hollow.core.type.FloatTypeAPI
-
- getDelegateLookupImpl() - Method in class com.netflix.hollow.core.type.IntegerTypeAPI
-
- getDelegateLookupImpl() - Method in class com.netflix.hollow.core.type.LongTypeAPI
-
- getDelegateLookupImpl() - Method in class com.netflix.hollow.core.type.StringTypeAPI
-
- getDeltasCompleted() - Method in class com.netflix.hollow.api.metrics.HollowProducerMetrics
-
- getDeltasFailed() - Method in class com.netflix.hollow.api.metrics.HollowProducerMetrics
-
- getDeltaTransitions() - Method in class com.netflix.hollow.api.client.HollowUpdatePlan
-
- getDesiredVersion() - Method in class com.netflix.hollow.api.consumer.metrics.ConsumerRefreshMetrics.UpdatePlanDetails
-
- getDesiredVersion() - Method in class com.netflix.hollow.api.producer.HollowProducerListener.RestoreStatus
-
- getDestinationRandomizedTag() - Method in class com.netflix.hollow.core.HollowBlobHeader
-
- getDestinationRandomizedTag() - Method in class com.netflix.hollow.core.HollowBlobOptionalPartHeader
-
- getDetails() - Method in class com.netflix.hollow.api.producer.validation.ValidationResult
-
Returns details associated with the validation.
- getDiffEqualityMapping() - Method in class com.netflix.hollow.tools.history.DiffEqualityMappingOrdinalRemapper
-
- getDouble(int, String) - Method in class com.netflix.hollow.api.objects.delegate.HollowObjectAbstractDelegate
-
- getDouble(int, String) - Method in interface com.netflix.hollow.api.objects.delegate.HollowObjectDelegate
-
- getDouble(String) - Method in class com.netflix.hollow.api.objects.HollowObject
-
- getDuplicateKeys() - Method in class com.netflix.hollow.core.index.HollowPrimaryKeyIndex
-
- getDurationMillis() - Method in class com.netflix.hollow.api.consumer.metrics.ConsumerRefreshMetrics
-
- getElementOrdinal(int, int) - Method in class com.netflix.hollow.api.custom.HollowListTypeAPI
-
- getElementOrdinal(int, int) - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowListDisabledDataAccess
-
- getElementOrdinal(int, int) - Method in interface com.netflix.hollow.core.read.dataaccess.HollowListTypeDataAccess
-
- getElementOrdinal(int, int) - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowListMissingDataAccess
-
- getElementOrdinal(int, int) - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowListProxyDataAccess
-
- getElementOrdinal(int, int) - Method in class com.netflix.hollow.core.read.engine.list.HollowListTypeReadState
-
- getElementOrdinal(int, int) - Method in class com.netflix.hollow.tools.history.HollowHistoricalListDataAccess
-
- getElementPathIdx(String) - Method in class com.netflix.hollow.tools.diff.specific.HollowSpecificDiff
-
- getElements(long) - Method in class com.netflix.hollow.core.memory.encoding.FixedLengthMultipleOccurrenceElementArray
-
Return a list of elements at the specified node index.
- getElementType() - Method in class com.netflix.hollow.core.schema.HollowCollectionSchema
-
- getElementType() - Method in class com.netflix.hollow.core.schema.HollowListSchema
-
- getElementType() - Method in class com.netflix.hollow.core.schema.HollowSetSchema
-
- getElementTypeState() - Method in class com.netflix.hollow.core.schema.HollowCollectionSchema
-
- getElementTypeState() - Method in class com.netflix.hollow.core.schema.HollowListSchema
-
- getElementTypeState() - Method in class com.netflix.hollow.core.schema.HollowSetSchema
-
- getElementValue(long, int) - Method in class com.netflix.hollow.core.memory.encoding.EncodedLongBuffer
-
- getElementValue(long, int, long) - Method in class com.netflix.hollow.core.memory.encoding.EncodedLongBuffer
-
- getElementValue(long, int) - Method in class com.netflix.hollow.core.memory.encoding.FixedLengthElementArray
-
- getElementValue(long, int, long) - Method in class com.netflix.hollow.core.memory.encoding.FixedLengthElementArray
-
- getElementValue(long, int) - Method in interface com.netflix.hollow.core.memory.FixedLengthData
-
Gets an element value, comprising of bitsPerElement
bits, at the given
bit index
.
- getElementValue(long, int, long) - Method in interface com.netflix.hollow.core.memory.FixedLengthData
-
Gets a masked element value, comprising of bitsPerElement
bits, at the given
bit index
.
- getEnclosingSchema() - Method in class com.netflix.hollow.core.index.FieldPaths.FieldSegment
-
Returns the enclosing schema that declares a field corresponding to this segment.
- getEnclosingSchema() - Method in class com.netflix.hollow.core.index.FieldPaths.ObjectFieldSegment
-
Returns the enclosing schema that declares a field corresponding to this segment.
- getEqualityDeterminer() - Method in class com.netflix.hollow.tools.diff.exact.mapper.DiffEqualityCollectionMapper
-
- getEqualityDeterminer() - Method in class com.netflix.hollow.tools.diff.exact.mapper.DiffEqualityMapMapper
-
- getEqualityDeterminer() - Method in class com.netflix.hollow.tools.diff.exact.mapper.DiffEqualityObjectMapper
-
- getEqualityDeterminer() - Method in class com.netflix.hollow.tools.diff.exact.mapper.DiffEqualityTypeMapper
-
- getEqualityMapping() - Method in class com.netflix.hollow.tools.diff.HollowDiff
-
- getEqualOrdinalMap(String) - Method in class com.netflix.hollow.tools.diff.exact.DiffEqualityMapping
-
- getEqualOrdinals(int) - Method in class com.netflix.hollow.tools.diff.exact.DiffEqualOrdinalMap
-
- getExtraInFrom() - Method in class com.netflix.hollow.tools.diff.HollowDiffMatcher
-
- getExtraInTo() - Method in class com.netflix.hollow.tools.diff.HollowDiffMatcher
-
- getFieldBitOffset(int) - Method in class com.netflix.hollow.core.write.FieldStatistics
-
- getFieldDiffs() - Method in class com.netflix.hollow.tools.diff.count.HollowDiffCollectionCountingNode
-
- getFieldDiffs() - Method in class com.netflix.hollow.tools.diff.count.HollowDiffCountingNode
-
- getFieldDiffs() - Method in class com.netflix.hollow.tools.diff.count.HollowDiffFieldCountingNode
-
- getFieldDiffs() - Method in class com.netflix.hollow.tools.diff.count.HollowDiffMapCountingNode
-
- getFieldDiffs() - Method in class com.netflix.hollow.tools.diff.count.HollowDiffMissingCountingNode
-
- getFieldDiffs() - Method in class com.netflix.hollow.tools.diff.count.HollowDiffObjectCountingNode
-
- getFieldDiffs() - Method in class com.netflix.hollow.tools.diff.count.HollowDiffShortcutTypeCountingNode
-
- getFieldDiffs() - Method in class com.netflix.hollow.tools.diff.HollowTypeDiff
-
Get the differences broken down by specific field paths
- getFieldIdentifier() - Method in class com.netflix.hollow.tools.diff.count.HollowFieldDiff
-
- getFieldName() - Method in exception com.netflix.hollow.api.error.IncompatibleSchemaException
-
- getFieldName(int) - Method in class com.netflix.hollow.core.schema.HollowObjectSchema
-
- getFieldPath(int) - Method in class com.netflix.hollow.core.index.key.PrimaryKey
-
- getFieldPath(int) - Method in class com.netflix.hollow.core.index.traversal.HollowIndexerValueTraverser
-
- getFieldPathIndex(HollowDataset, int) - Method in class com.netflix.hollow.core.index.key.PrimaryKey
-
The field path index is the object schemas' field positions for a particular field path.
- getFieldPathIndex(HollowDataset, String, String) - Static method in class com.netflix.hollow.core.index.key.PrimaryKey
-
The field path index is the object schemas' field positions for a particular field path.
- getFieldPathIndexes() - Method in class com.netflix.hollow.core.index.key.HollowPrimaryKeyValueDeriver
-
- getFieldPathIndexes(HollowReadStateEngine, PrimaryKey) - Static method in class com.netflix.hollow.tools.util.SearchUtils
-
Return field index in object schema for each field comprising primary key.
- getFieldPaths() - Method in class com.netflix.hollow.core.index.key.PrimaryKey
-
- getFieldSchema(HollowDataset, int) - Method in class com.netflix.hollow.core.index.key.PrimaryKey
-
- getFieldSchema(HollowDataset, String, String) - Static method in class com.netflix.hollow.core.index.key.PrimaryKey
-
Returns the ultimate field Schema of the specified type/field path in the provided dataset.
- getFieldType() - Method in exception com.netflix.hollow.api.error.IncompatibleSchemaException
-
- getFieldType() - Method in class com.netflix.hollow.core.index.HollowHashIndexField
-
- getFieldType(HollowDataset, int) - Method in class com.netflix.hollow.core.index.key.PrimaryKey
-
- getFieldType(HollowDataset, String, String) - Static method in class com.netflix.hollow.core.index.key.PrimaryKey
-
Returns the ultimate field type of the specified type/field path in the provided dataset.
- getFieldType(String) - Method in class com.netflix.hollow.core.schema.HollowObjectSchema
-
- getFieldType(int) - Method in class com.netflix.hollow.core.schema.HollowObjectSchema
-
- getFieldTypeDataAccess(int) - Method in class com.netflix.hollow.core.index.traversal.HollowIndexerValueTraverser
-
- getFieldTypes() - Method in class com.netflix.hollow.core.index.HollowPrimaryKeyIndex
-
- getFieldTypes() - Method in class com.netflix.hollow.core.index.key.HollowPrimaryKeyValueDeriver
-
- getFieldTypes() - Method in class com.netflix.hollow.tools.history.HistoricalPrimaryKeyMatcher
-
- getFile() - Method in class com.netflix.hollow.api.client.HollowBlob
-
Deprecated.
- getFile() - Method in class com.netflix.hollow.api.consumer.HollowConsumer.Blob
-
- getFile() - Method in class com.netflix.hollow.api.producer.fs.HollowFilesystemBlobStager.FilesystemBlob
-
- getFile() - Method in class com.netflix.hollow.api.producer.HollowProducer.Blob
-
Deprecated.
- getFile(String) - Method in class com.netflix.hollow.core.read.OptionalBlobPartInput
-
- getFilePointer() - Method in class com.netflix.hollow.core.read.HollowBlobInput
-
Returns the current offset in this input at which the next read would occur.
- getFinalBitsPerMatchHashEntry() - Method in class com.netflix.hollow.core.index.HollowHashIndexBuilder
-
- getFinalBitsPerSelectTablePointer() - Method in class com.netflix.hollow.core.index.HollowHashIndexBuilder
-
- getFinalBitsPerSelectTableSize() - Method in class com.netflix.hollow.core.index.HollowHashIndexBuilder
-
- getFinalMatchHashMask() - Method in class com.netflix.hollow.core.index.HollowHashIndexBuilder
-
- getFinalMatchHashTable() - Method in class com.netflix.hollow.core.index.HollowHashIndexBuilder
-
- getFinalSelectHashArray() - Method in class com.netflix.hollow.core.index.HollowHashIndexBuilder
-
- getFixedLength() - Method in enum com.netflix.hollow.core.schema.HollowObjectSchema.FieldType
-
- getFloat(int, String) - Method in class com.netflix.hollow.api.objects.delegate.HollowObjectAbstractDelegate
-
- getFloat(int, String) - Method in interface com.netflix.hollow.api.objects.delegate.HollowObjectDelegate
-
- getFloat(String) - Method in class com.netflix.hollow.api.objects.HollowObject
-
- getForOrdinal(int) - Method in class com.netflix.hollow.core.util.HollowRecordCollection
-
- getFreeOrdinal() - Method in class com.netflix.hollow.core.memory.FreeOrdinalTracker
-
- getFromOrdinal(int) - Method in class com.netflix.hollow.tools.diff.count.HollowFieldDiff
-
- getFromOrdinalIdentityTranslator() - Method in class com.netflix.hollow.tools.diff.exact.DiffEqualOrdinalMap
-
- getFromStateEngine() - Method in class com.netflix.hollow.tools.diff.HollowDiff
-
- getFromTypeState() - Method in class com.netflix.hollow.tools.diff.HollowTypeDiff
-
- getFromVersion() - Method in class com.netflix.hollow.api.client.HollowBlob
-
Deprecated.
- getFromVersion() - Method in class com.netflix.hollow.api.consumer.HollowConsumer.Blob
-
- getFromVersion() - Method in class com.netflix.hollow.api.producer.HollowProducer.Blob
-
- getGetterPrefix() - Method in class com.netflix.hollow.api.codegen.CodeGeneratorConfig
-
- getHashCodeFinder() - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowDisabledDataAccess
-
- getHashCodeFinder() - Method in interface com.netflix.hollow.core.read.dataaccess.HollowDataAccess
-
Deprecated.
- getHashCodeFinder() - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowProxyDataAccess
-
- getHashCodeFinder() - Method in class com.netflix.hollow.core.read.engine.HollowReadStateEngine
-
- getHashCodeFinder() - Method in class com.netflix.hollow.core.write.HollowWriteStateEngine
-
Deprecated.
- getHashCodeFinder() - Method in class com.netflix.hollow.tools.history.HollowHistoricalStateDataAccess
-
- getHashKey() - Method in class com.netflix.hollow.core.schema.HollowMapSchema
-
- getHashKey() - Method in class com.netflix.hollow.core.schema.HollowSetSchema
-
- getHBoolean(int) - Method in interface com.netflix.hollow.api.consumer.HollowConsumerAPI.BooleanRetriever
-
- getHDouble(int) - Method in interface com.netflix.hollow.api.consumer.HollowConsumerAPI.DoubleRetriever
-
- getHeaderEntries() - Method in class com.netflix.hollow.tools.history.HollowHistoricalState
-
- getHeaderTag(String) - Method in interface com.netflix.hollow.core.HollowStateEngine
-
- getHeaderTag(String) - Method in class com.netflix.hollow.core.read.engine.HollowReadStateEngine
-
- getHeaderTag(String) - Method in class com.netflix.hollow.core.write.HollowWriteStateEngine
-
- getHeaderTags() - Method in class com.netflix.hollow.core.HollowBlobHeader
-
- getHeaderTags() - Method in interface com.netflix.hollow.core.HollowStateEngine
-
- getHeaderTags() - Method in class com.netflix.hollow.core.read.engine.HollowReadStateEngine
-
- getHeaderTags() - Method in class com.netflix.hollow.core.write.HollowWriteStateEngine
-
- getHFloat(int) - Method in interface com.netflix.hollow.api.consumer.HollowConsumerAPI.FloatRetriever
-
- getHInteger(int) - Method in interface com.netflix.hollow.api.consumer.HollowConsumerAPI.IntegerRetriever
-
- getHistoricalState(long) - Method in class com.netflix.hollow.tools.history.HollowHistory
-
- getHistoricalStates() - Method in class com.netflix.hollow.tools.history.HollowHistory
-
- getHLong(int) - Method in interface com.netflix.hollow.api.consumer.HollowConsumerAPI.LongRetriever
-
- getHollowDiffCountingNode(HollowTypeReadState, HollowTypeReadState, String) - Method in class com.netflix.hollow.tools.diff.count.HollowDiffCountingNode
-
- getHollowFactoryGenerator(HollowSchema) - Method in class com.netflix.hollow.api.codegen.HollowAPIGenerator
-
- getHollowObject(int) - Method in class com.netflix.hollow.api.objects.provider.HollowObjectCacheProvider
-
- getHollowObject(int) - Method in class com.netflix.hollow.api.objects.provider.HollowObjectFactoryProvider
-
- getHollowObject(int) - Method in class com.netflix.hollow.api.objects.provider.HollowObjectProvider
-
- getHollowObjectGenerator(HollowSchema) - Method in class com.netflix.hollow.api.codegen.HollowAPIGenerator
-
- getHString(int) - Method in interface com.netflix.hollow.api.consumer.HollowConsumerAPI.StringRetriever
-
- getIdentifier() - Method in class com.netflix.hollow.api.sampling.SampleResult
-
- getIdentityFromOrdinal(int) - Method in class com.netflix.hollow.tools.diff.exact.DiffEqualOrdinalMap
-
- getIdentityOrdinal(int) - Method in interface com.netflix.hollow.tools.diff.exact.DiffEqualOrdinalMap.OrdinalIdentityTranslator
-
- getIdentityToOrdinal(int) - Method in class com.netflix.hollow.tools.diff.exact.DiffEqualOrdinalMap
-
- getIndex() - Method in class com.netflix.hollow.core.index.FieldPaths.ObjectFieldSegment
-
The field index in the enclosing object schema.
- getInitialLoad() - Method in class com.netflix.hollow.api.client.HollowClientUpdater
-
- getInitialLoad() - Method in class com.netflix.hollow.api.consumer.HollowConsumer
-
Returns a CompletableFuture
that completes after the initial data load succeeds.
- getInput() - Method in class com.netflix.hollow.core.read.HollowBlobInput
-
- getInputsByPartName(MemoryMode) - Method in class com.netflix.hollow.core.read.OptionalBlobPartInput
-
- getInputStateEngine() - Method in class com.netflix.hollow.tools.split.HollowSplitter
-
- getInputStream() - Method in class com.netflix.hollow.api.client.HollowBlob
-
Deprecated.
Implementations will define how to retrieve the actual blob data for this specific transition from a data store.
- getInputStream() - Method in class com.netflix.hollow.api.consumer.HollowConsumer.Blob
-
Implementations will define how to retrieve the actual blob data for this specific transition from a data store.
- getInputStream(String) - Method in class com.netflix.hollow.core.read.OptionalBlobPartInput
-
- getInputStreamsByPartName() - Method in class com.netflix.hollow.core.read.OptionalBlobPartInput
-
- getInt(int, String) - Method in class com.netflix.hollow.api.objects.delegate.HollowObjectAbstractDelegate
-
- getInt(int, String) - Method in interface com.netflix.hollow.api.objects.delegate.HollowObjectDelegate
-
- getInt(String) - Method in class com.netflix.hollow.api.objects.HollowObject
-
- getIsAnnouncementSuccess() - Method in class com.netflix.hollow.api.producer.metrics.AnnouncementMetrics
-
- getIsCycleSuccess() - Method in class com.netflix.hollow.api.producer.metrics.CycleMetrics
-
- getIsInitialLoad() - Method in class com.netflix.hollow.api.consumer.metrics.ConsumerRefreshMetrics
-
- getIsRefreshSuccess() - Method in class com.netflix.hollow.api.consumer.metrics.ConsumerRefreshMetrics
-
- getJavaBoxedType(HollowObjectSchema.FieldType) - Static method in class com.netflix.hollow.api.codegen.HollowCodeGenerationUtils
-
- getJavaScalarType(HollowObjectSchema.FieldType) - Static method in class com.netflix.hollow.api.codegen.HollowCodeGenerationUtils
-
- getKey() - Method in class com.netflix.hollow.api.codegen.ArgumentParser.ParsedArgument
-
- getKey() - Method in class com.netflix.hollow.core.read.engine.map.PotentialMatchHollowMapEntryOrdinalIteratorImpl
-
- getKey() - Method in class com.netflix.hollow.core.read.iterator.EmptyMapOrdinalIterator
-
- getKey() - Method in interface com.netflix.hollow.core.read.iterator.HollowMapEntryOrdinalIterator
-
- getKey() - Method in class com.netflix.hollow.core.read.iterator.HollowMapEntryOrdinalIteratorImpl
-
- getKey() - Method in class com.netflix.hollow.core.util.IntMap.IntMapEntryIterator
-
- getKey() - Method in class com.netflix.hollow.core.write.objectmapper.RecordPrimaryKey
-
- getKeyDeriver() - Method in class com.netflix.hollow.core.read.engine.map.HollowMapTypeReadState
-
- getKeyDeriver() - Method in class com.netflix.hollow.core.read.engine.set.HollowSetTypeReadState
-
- getKeyDisplayString(HollowObjectTypeReadState, int) - Method in class com.netflix.hollow.tools.diff.HollowDiffMatcher
-
- getKeyDisplayString(String, int) - Method in class com.netflix.hollow.tools.history.keyindex.HollowHistoryKeyIndex
-
- getKeyDisplayString(int) - Method in class com.netflix.hollow.tools.history.keyindex.HollowHistoryTypeKeyIndex
-
- getKeyFields() - Method in class com.netflix.hollow.tools.history.keyindex.HollowHistoryTypeKeyIndex
-
- getKeyFieldValue(int, int) - Method in class com.netflix.hollow.tools.history.keyindex.HollowHistoryTypeKeyIndex
-
- getKeyIndex() - Method in class com.netflix.hollow.tools.history.HollowHistory
-
- getKeyIndex() - Method in class com.netflix.hollow.tools.history.keyindex.HollowHistoricalStateTypeKeyOrdinalMapping
-
- getKeyMatchingValues() - Method in class com.netflix.hollow.tools.patch.record.TypeMatchSpec
-
- getKeyOrdinalMapping() - Method in class com.netflix.hollow.tools.history.HollowHistoricalState
-
- getKeyPaths() - Method in class com.netflix.hollow.tools.patch.record.TypeMatchSpec
-
- getKeys(int) - Method in class com.netflix.hollow.core.index.HollowPrefixIndex
-
Return the key to index in prefix index.
- getKeyType() - Method in class com.netflix.hollow.core.schema.HollowMapSchema
-
- getKeyTypeState() - Method in class com.netflix.hollow.core.schema.HollowMapSchema
-
- getLargeElementValue(long, int) - Method in class com.netflix.hollow.core.memory.encoding.EncodedLongBuffer
-
- getLargeElementValue(long, int, long) - Method in class com.netflix.hollow.core.memory.encoding.EncodedLongBuffer
-
- getLargeElementValue(long, int) - Method in class com.netflix.hollow.core.memory.encoding.FixedLengthElementArray
-
- getLargeElementValue(long, int, long) - Method in class com.netflix.hollow.core.memory.encoding.FixedLengthElementArray
-
- getLargeElementValue(long, int) - Method in interface com.netflix.hollow.core.memory.FixedLengthData
-
Gets a large element value, comprising of bitsPerElement
bits, at the given
bit index
.
- getLargeElementValue(long, int, long) - Method in interface com.netflix.hollow.core.memory.FixedLengthData
-
Gets a masked large element value, comprising of bitsPerElement
bits, at the given
bit index
.
- getLastAnnouncementSuccessTimeNano() - Method in class com.netflix.hollow.api.producer.metrics.AnnouncementMetrics
-
- getLastCycleSuccessTimeNano() - Method in class com.netflix.hollow.api.producer.metrics.CycleMetrics
-
- getLatestState() - Method in class com.netflix.hollow.tools.history.HollowHistory
-
- getLatestVersion() - Method in class com.netflix.hollow.api.client.HollowAnnouncementWatcher.DefaultWatcher
-
Deprecated.
- getLatestVersion() - Method in class com.netflix.hollow.api.client.HollowAnnouncementWatcher
-
Deprecated.
- getLatestVersion() - Method in class com.netflix.hollow.api.consumer.fs.HollowFilesystemAnnouncementWatcher
-
- getLatestVersion() - Method in interface com.netflix.hollow.api.consumer.HollowConsumer.AnnouncementWatcher
-
- getList(String) - Method in class com.netflix.hollow.api.objects.generic.GenericHollowObject
-
- getListener(Class<T>) - Method in class com.netflix.hollow.core.read.engine.HollowTypeReadState
-
- getListeners(Class<T>) - Method in class com.netflix.hollow.api.common.Listeners
-
- getListeners() - Method in class com.netflix.hollow.core.read.engine.HollowTypeReadState
-
- getLog2OfByteSegmentSize() - Method in interface com.netflix.hollow.core.memory.pool.ArraySegmentRecycler
-
- getLog2OfByteSegmentSize() - Method in class com.netflix.hollow.core.memory.pool.RecyclingRecycler
-
- getLog2OfByteSegmentSize() - Method in class com.netflix.hollow.core.memory.pool.WastefulRecycler
-
- getLog2OfLongSegmentSize() - Method in interface com.netflix.hollow.core.memory.pool.ArraySegmentRecycler
-
- getLog2OfLongSegmentSize() - Method in class com.netflix.hollow.core.memory.pool.RecyclingRecycler
-
- getLog2OfLongSegmentSize() - Method in class com.netflix.hollow.core.memory.pool.WastefulRecycler
-
- getLong(int, String) - Method in class com.netflix.hollow.api.objects.delegate.HollowObjectAbstractDelegate
-
- getLong(int, String) - Method in interface com.netflix.hollow.api.objects.delegate.HollowObjectDelegate
-
- getLong(String) - Method in class com.netflix.hollow.api.objects.HollowObject
-
- getLong(long) - Method in class com.netflix.hollow.core.memory.encoding.BlobByteBuffer
-
Return the long value starting from given byte index.
- getLongArray() - Method in interface com.netflix.hollow.core.memory.pool.ArraySegmentRecycler
-
- getLongArray() - Method in class com.netflix.hollow.core.memory.pool.RecyclingRecycler
-
- getLongArray() - Method in class com.netflix.hollow.core.memory.pool.WastefulRecycler
-
- getMap(String) - Method in class com.netflix.hollow.api.objects.generic.GenericHollowObject
-
- getMappedOrdinal(String, int) - Method in class com.netflix.hollow.tools.combine.HollowCombinerOrdinalRemapper
-
- getMappedOrdinal(String, int) - Method in class com.netflix.hollow.tools.combine.IdentityOrdinalRemapper
-
- getMappedOrdinal(String, int) - Method in interface com.netflix.hollow.tools.combine.OrdinalRemapper
-
- getMappedOrdinal(String, int) - Method in class com.netflix.hollow.tools.history.DiffEqualityMappingOrdinalRemapper
-
- getMappedOrdinal(int) - Method in class com.netflix.hollow.tools.history.HollowHistoricalTypeDataAccess
-
- getMappedOrdinal(String, int) - Method in class com.netflix.hollow.tools.history.IntMapOrdinalRemapper
-
- getMappedOrdinal(String, int) - Method in class com.netflix.hollow.tools.patch.delta.PartialOrdinalRemapper
-
- getMappedOrdinal(String, int) - Method in class com.netflix.hollow.tools.split.HollowSplitterOrdinalRemapper
-
- getMatchedFromOrdinals() - Method in class com.netflix.hollow.tools.diff.exact.DiffEqualOrdinalFilter
-
- getMatchedOrdinals() - Method in class com.netflix.hollow.tools.diff.HollowDiffMatcher
-
- getMatchedToOrdinals() - Method in class com.netflix.hollow.tools.diff.exact.DiffEqualOrdinalFilter
-
- getMatchedValue(int, int) - Method in class com.netflix.hollow.core.index.traversal.HollowIndexerValueTraverser
-
- getMatcher() - Method in class com.netflix.hollow.tools.diff.HollowTypeDiff
-
- getMatchFields() - Method in class com.netflix.hollow.core.index.HollowHashIndex
-
- getMatchFields() - Method in class com.netflix.hollow.core.index.HollowHashIndex.HollowHashIndexState
-
- getMatchFields() - Method in class com.netflix.hollow.core.index.HollowHashIndexBuilder
-
- getMatchFieldSpecs() - Method in class com.netflix.hollow.core.index.HollowPreindexer
-
- getMatchHash(int) - Method in class com.netflix.hollow.core.index.traversal.HollowIndexerValueTraverser
-
- getMatchHash(int, BitSet) - Method in class com.netflix.hollow.core.index.traversal.HollowIndexerValueTraverser
-
- getMatchHashMask() - Method in class com.netflix.hollow.core.index.HollowHashIndex.HollowHashIndexState
-
- getMatchHashTable() - Method in class com.netflix.hollow.core.index.HollowHashIndex.HollowHashIndexState
-
- getMatchingOrdinal(Object) - Method in class com.netflix.hollow.core.index.HollowPrimaryKeyIndex
-
Query an index with a single specified field.
- getMatchingOrdinal(Object, Object) - Method in class com.netflix.hollow.core.index.HollowPrimaryKeyIndex
-
Query an index with two specified fields.
- getMatchingOrdinal(Object, Object, Object) - Method in class com.netflix.hollow.core.index.HollowPrimaryKeyIndex
-
Query an index with three specified fields.
- getMatchingOrdinal(Object...) - Method in class com.netflix.hollow.core.index.HollowPrimaryKeyIndex
-
Query an index with four or more specified fields.
- getMatchOrdinal(int, int) - Method in class com.netflix.hollow.core.index.traversal.HollowIndexerValueTraverser
-
- getMatchPaths() - Method in class com.netflix.hollow.tools.diff.HollowDiffMatcher
-
- getMaxBitsForField(int) - Method in class com.netflix.hollow.core.write.FieldStatistics
-
- getMemoryMode() - Method in class com.netflix.hollow.core.read.HollowBlobInput
-
- getMemoryRecycler() - Method in class com.netflix.hollow.core.read.engine.HollowReadStateEngine
-
- getMessage() - Method in class com.netflix.hollow.api.producer.validation.ValidationResult
-
Returns a message associated with the validation.
- getMetrics() - Method in class com.netflix.hollow.api.consumer.HollowConsumer
-
- getMetrics() - Method in class com.netflix.hollow.api.metrics.HollowMetricsCollector
-
- getMetrics() - Method in class com.netflix.hollow.api.producer.HollowProducer
-
- getMinCandidateHoleCostInBytes() - Method in class com.netflix.hollow.tools.compact.HollowCompactor.CompactionConfig
-
- getMinCandidateHolePercentage() - Method in class com.netflix.hollow.tools.compact.HollowCompactor.CompactionConfig
-
- getMissingDataHandler() - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowDisabledDataAccess
-
- getMissingDataHandler() - Method in interface com.netflix.hollow.core.read.dataaccess.HollowDataAccess
-
- getMissingDataHandler() - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowProxyDataAccess
-
- getMissingDataHandler() - Method in class com.netflix.hollow.core.read.engine.HollowReadStateEngine
-
- getMissingDataHandler() - Method in class com.netflix.hollow.tools.history.HollowHistoricalStateDataAccess
-
- getName() - Method in class com.netflix.hollow.api.producer.validation.DuplicateDataDetectionValidator
-
- getName() - Method in class com.netflix.hollow.api.producer.validation.ObjectModificationValidator
-
- getName() - Method in class com.netflix.hollow.api.producer.validation.RecordCountVarianceValidator
-
- getName() - Method in class com.netflix.hollow.api.producer.validation.ValidationResult
-
Returns the name of the validation performed.
- getName() - Method in interface com.netflix.hollow.api.producer.validation.ValidatorListener
-
Gets the name of the validator.
- getName() - Method in class com.netflix.hollow.core.index.FieldPaths.FieldSegment
-
Returns the segment name.
- getName() - Method in class com.netflix.hollow.core.schema.HollowSchema
-
- getNextState() - Method in class com.netflix.hollow.tools.history.HollowHistoricalState
-
- getNextState() - Method in class com.netflix.hollow.tools.history.HollowHistoricalStateDataAccess
-
- getNextStateRandomizedTag() - Method in class com.netflix.hollow.core.write.HollowWriteStateEngine
-
- getNodeName() - Method in class com.netflix.hollow.tools.diff.HollowDiffNodeIdentifier
-
- getNonNullSchema(String) - Method in interface com.netflix.hollow.core.HollowDataset
-
- getNonNullSchema(String) - Method in interface com.netflix.hollow.core.HollowStateEngine
-
- getNonNullSchema(String) - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowDisabledDataAccess
-
- getNonNullSchema(String) - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowProxyDataAccess
-
- getNonNullSchema(String) - Method in class com.netflix.hollow.core.read.engine.HollowReadStateEngine
-
- getNonNullSchema(String) - Method in class com.netflix.hollow.core.schema.SimpleHollowDataset
-
- getNonNullSchema(String) - Method in class com.netflix.hollow.core.write.HollowWriteStateEngine
-
- getNonNullSchema(String) - Method in class com.netflix.hollow.tools.history.HollowHistoricalStateDataAccess
-
- getNumberOfHistoricalStates() - Method in class com.netflix.hollow.tools.history.HollowHistory
-
- getNumberOfModifiedRecords() - Method in class com.netflix.hollow.tools.history.keyindex.HollowHistoricalStateTypeKeyOrdinalMapping
-
- getNumberOfNewRecords() - Method in class com.netflix.hollow.tools.history.keyindex.HollowHistoricalStateTypeKeyOrdinalMapping
-
- getNumberOfRemovedRecords() - Method in class com.netflix.hollow.tools.history.keyindex.HollowHistoricalStateTypeKeyOrdinalMapping
-
- getNumberOfShards() - Method in class com.netflix.hollow.tools.split.HollowSplitter
-
- getNumBitsPerRecord() - Method in class com.netflix.hollow.core.write.FieldStatistics
-
- getNumDiffs() - Method in class com.netflix.hollow.tools.diff.count.HollowFieldDiff
-
- getNumFailedDeltaTransitions() - Method in class com.netflix.hollow.api.client.FailedTransitionTracker
-
- getNumFailedDeltaTransitions() - Method in class com.netflix.hollow.api.client.HollowClientUpdater
-
- getNumFailedDeltaTransitions() - Method in class com.netflix.hollow.api.consumer.HollowConsumer
-
- getNumFailedSnapshotTransitions() - Method in class com.netflix.hollow.api.client.FailedTransitionTracker
-
- getNumFailedSnapshotTransitions() - Method in class com.netflix.hollow.api.client.HollowClientUpdater
-
- getNumFailedSnapshotTransitions() - Method in class com.netflix.hollow.api.consumer.HollowConsumer
-
- getNumFieldPaths() - Method in class com.netflix.hollow.core.index.traversal.HollowIndexerValueTraverser
-
- getNumMatches() - Method in class com.netflix.hollow.core.index.traversal.HollowIndexerValueTraverser
-
- getNumMatchTraverserFields() - Method in class com.netflix.hollow.core.index.HollowPreindexer
-
- getNumSamples() - Method in class com.netflix.hollow.api.sampling.SampleResult
-
- getNumShards() - Method in interface com.netflix.hollow.tools.split.HollowSplitterCopyDirector
-
- getNumShards() - Method in class com.netflix.hollow.tools.split.HollowSplitterOrdinalCopyDirector
-
- getNumShards() - Method in class com.netflix.hollow.tools.split.HollowSplitterPrimaryKeyCopyDirector
-
- getNumSuccessfulTransitions() - Method in class com.netflix.hollow.api.consumer.metrics.ConsumerRefreshMetrics.UpdatePlanDetails
-
- getObject(int) - Method in class com.netflix.hollow.api.objects.generic.GenericHollowList
-
- getObject(String) - Method in class com.netflix.hollow.api.objects.generic.GenericHollowObject
-
- getObjectMapper() - Method in class com.netflix.hollow.api.producer.HollowProducer
-
- getObjectMapper() - Method in interface com.netflix.hollow.api.producer.HollowProducer.WriteState
-
- getObjectTypeConfig(String) - Method in class com.netflix.hollow.core.read.filter.HollowFilterConfig
-
Deprecated.
- getOffsetPerTraverserField() - Method in class com.netflix.hollow.core.index.HollowHashIndex.HollowHashIndexState
-
- getOffsetPerTraverserField() - Method in class com.netflix.hollow.core.index.HollowHashIndexBuilder
-
- getOptionalBlobPartInputs() - Method in class com.netflix.hollow.api.consumer.HollowConsumer.Blob
-
Implementations may define how to retrieve the optional blob part data for this specific transition from a data store.
- getOptionalPartConfig() - Method in class com.netflix.hollow.api.producer.HollowProducer.Blob
-
- getOptionalPartPath(String) - Method in class com.netflix.hollow.api.producer.fs.HollowFilesystemBlobStager.FilesystemBlob
-
- getOptionalPartPath(String) - Method in class com.netflix.hollow.api.producer.fs.HollowInMemoryBlobStager.InMemoryBlob
-
- getOptionalPartPath(String) - Method in class com.netflix.hollow.api.producer.HollowProducer.Blob
-
- getOrAssignOrdinal(ByteDataArray) - Method in class com.netflix.hollow.core.memory.ByteArrayOrdinalMap
-
- getOrAssignOrdinal(ByteDataArray, int) - Method in class com.netflix.hollow.core.memory.ByteArrayOrdinalMap
-
Adds a sequence of bytes to this map.
- getOrderedTypeStates() - Method in class com.netflix.hollow.core.write.HollowWriteStateEngine
-
- getOrdinal(int, String) - Method in class com.netflix.hollow.api.objects.delegate.HollowObjectAbstractDelegate
-
- getOrdinal(int, String) - Method in interface com.netflix.hollow.api.objects.delegate.HollowObjectDelegate
-
- getOrdinal() - Method in class com.netflix.hollow.api.objects.HollowList
-
- getOrdinal() - Method in class com.netflix.hollow.api.objects.HollowMap
-
- getOrdinal() - Method in class com.netflix.hollow.api.objects.HollowObject
-
- getOrdinal(String) - Method in class com.netflix.hollow.api.objects.HollowObject
-
- getOrdinal() - Method in interface com.netflix.hollow.api.objects.HollowRecord
-
- getOrdinal() - Method in class com.netflix.hollow.api.objects.HollowSet
-
- getOrdinal(long) - Static method in class com.netflix.hollow.core.memory.ByteArrayOrdinalMap
-
- getOrdinalIterator(int) - Method in class com.netflix.hollow.api.custom.HollowListTypeAPI
-
- getOrdinalIterator(int) - Method in class com.netflix.hollow.api.custom.HollowMapTypeAPI
-
- getOrdinalIterator(int) - Method in class com.netflix.hollow.api.custom.HollowSetTypeAPI
-
- getOrdinalMapping() - Method in class com.netflix.hollow.core.read.engine.list.HollowListDeltaHistoricalStateCreator
-
- getOrdinalMapping() - Method in class com.netflix.hollow.core.read.engine.map.HollowMapDeltaHistoricalStateCreator
-
- getOrdinalMapping() - Method in class com.netflix.hollow.core.read.engine.object.HollowObjectDeltaHistoricalStateCreator
-
- getOrdinalMapping() - Method in class com.netflix.hollow.core.read.engine.set.HollowSetDeltaHistoricalStateCreator
-
- getOrdinalMapping() - Method in class com.netflix.hollow.tools.history.HollowHistoricalStateDataAccess
-
- getOrdinalRemapping(String) - Method in class com.netflix.hollow.tools.history.IntMapOrdinalRemapper
-
- getOrdinalRemapping(String) - Method in class com.netflix.hollow.tools.patch.delta.PartialOrdinalRemapper
-
- getOrdinalToDisplay(HollowReadStateEngine, String, Object[], int, BitSet, int[][], HollowTypeReadState) - Static method in class com.netflix.hollow.tools.util.SearchUtils
-
Returns the ordinal corresponding to the search result of searching by primary key.
- getOriginRandomizedTag() - Method in class com.netflix.hollow.core.HollowBlobHeader
-
- getOriginRandomizedTag() - Method in class com.netflix.hollow.core.HollowBlobOptionalPartHeader
-
- getOtherType() - Method in exception com.netflix.hollow.api.error.IncompatibleSchemaException
-
- getOutputShardStateEngine(int) - Method in class com.netflix.hollow.tools.split.HollowSplitter
-
- getOverallRefreshType() - Method in class com.netflix.hollow.api.consumer.metrics.ConsumerRefreshMetrics
-
- getPairScore(int) - Method in class com.netflix.hollow.tools.diff.count.HollowFieldDiff
-
- getParents() - Method in class com.netflix.hollow.tools.diff.HollowDiffNodeIdentifier
-
- getParsedArguments() - Method in class com.netflix.hollow.api.codegen.ArgumentParser
-
- getPartName() - Method in class com.netflix.hollow.api.producer.ProducerOptionalBlobPartConfig.ConfiguredOutputStream
-
- getPartName() - Method in class com.netflix.hollow.core.HollowBlobOptionalPartHeader
-
- getPartNameByType() - Method in class com.netflix.hollow.api.producer.ProducerOptionalBlobPartConfig.OptionalBlobPartOutputStreams
-
- getPartNames() - Method in class com.netflix.hollow.core.read.OptionalBlobPartInput
-
- getParts() - Method in class com.netflix.hollow.api.producer.ProducerOptionalBlobPartConfig
-
- getPartStreams() - Method in class com.netflix.hollow.api.producer.ProducerOptionalBlobPartConfig.OptionalBlobPartOutputStreams
-
- getPath() - Method in class com.netflix.hollow.api.codegen.HollowErgonomicAPIShortcuts.Shortcut
-
- getPath() - Method in class com.netflix.hollow.api.producer.fs.HollowFilesystemBlobStager.FilesystemBlob
-
- getPath() - Method in class com.netflix.hollow.api.producer.HollowProducer.Blob
-
- getPathTypes() - Method in class com.netflix.hollow.api.codegen.HollowErgonomicAPIShortcuts.Shortcut
-
- getPointer(long) - Static method in class com.netflix.hollow.core.memory.ByteArrayOrdinalMap
-
- getPointerForData(int) - Method in class com.netflix.hollow.core.memory.ByteArrayOrdinalMap
-
- getPointersAndOrdinals() - Method in class com.netflix.hollow.core.memory.ByteArrayOrdinalMap
-
- getPopulatedBitSet() - Method in class com.netflix.hollow.core.write.HollowTypeWriteState
-
- getPopulatedOrdinals() - Method in class com.netflix.hollow.core.read.engine.HollowTypeReadState
-
Returns the BitSet containing the currently populated ordinals in this type state.
- getPopulatedOrdinals() - Method in class com.netflix.hollow.core.read.engine.PopulatedOrdinalListener
-
- getPosition(String) - Method in class com.netflix.hollow.core.schema.HollowObjectSchema
-
Returns the position of a field previously added to the map, or -1 if the field has not been added to the map.
- getPreviousCyclePopulatedBitSet() - Method in class com.netflix.hollow.core.write.HollowTypeWriteState
-
- getPreviousOrdinals() - Method in class com.netflix.hollow.core.read.engine.HollowTypeReadState
-
Returns the BitSet containing the populated ordinals in this type state prior to the previous delta transition.
- getPreviousOrdinals() - Method in class com.netflix.hollow.core.read.engine.PopulatedOrdinalListener
-
- getPreviousStateRandomizedTag() - Method in class com.netflix.hollow.core.write.HollowWriteStateEngine
-
- getPrimaryKey() - Method in class com.netflix.hollow.api.consumer.data.AbstractHollowDataAccessor
-
- getPrimaryKey() - Method in class com.netflix.hollow.core.index.HollowPrimaryKeyIndex
-
- getPrimaryKey() - Method in class com.netflix.hollow.core.schema.HollowObjectSchema
-
- getPrimaryKey(HollowSchema) - Static method in class com.netflix.hollow.tools.util.SearchUtils
-
Get the primary key for an object schema.
- getPrimaryKeyFieldTypes(int) - Method in interface com.netflix.hollow.core.write.objectmapper.flatrecords.HollowSchemaIdentifierMapper
-
- getPrimaryKeys() - Method in class com.netflix.hollow.tools.combine.HollowCombiner
-
- getPrimitiveTypes(Collection<HollowSchema>) - Static method in class com.netflix.hollow.api.codegen.HollowCodeGenerationUtils
-
- getPriorState() - Method in interface com.netflix.hollow.api.producer.HollowProducer.WriteState
-
For advanced use-cases, access the ReadState of the prior successful cycle.
- getProxiedDataAccess() - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowProxyDataAccess
-
- getReadState() - Method in class com.netflix.hollow.api.producer.HollowProducerListener.ProducerStatus
-
Returns the resulting read state engine after adding new data into write state engine.
- getReadTypeState() - Method in class com.netflix.hollow.core.write.copy.HollowRecordCopier
-
- getRecord(int) - Method in class com.netflix.hollow.api.consumer.data.AbstractHollowDataAccessor
-
- getRecord(int) - Method in class com.netflix.hollow.api.consumer.data.GenericHollowRecordDataAccessor
-
- getRecord(int) - Method in class com.netflix.hollow.core.type.accessor.BooleanDataAccessor
-
- getRecord(int) - Method in class com.netflix.hollow.core.type.accessor.DoubleDataAccessor
-
- getRecord(int) - Method in class com.netflix.hollow.core.type.accessor.FloatDataAccessor
-
- getRecord(int) - Method in class com.netflix.hollow.core.type.accessor.IntegerDataAccessor
-
- getRecord(int) - Method in class com.netflix.hollow.core.type.accessor.LongDataAccessor
-
- getRecord(int) - Method in class com.netflix.hollow.core.type.accessor.StringDataAccessor
-
- getRecordKey(int) - Method in class com.netflix.hollow.core.index.HollowPrimaryKeyIndex
-
- getRecordKey(int) - Method in class com.netflix.hollow.core.index.key.HollowPrimaryKeyValueDeriver
-
Retrieve the primary key value for the specified ordinal.
- getRecordKeyOrdinal(HollowObjectTypeReadState, int) - Method in class com.netflix.hollow.tools.history.keyindex.HollowHistoryKeyIndex
-
- getRecordPrimaryKey() - Method in class com.netflix.hollow.core.write.objectmapper.flatrecords.FlatRecord
-
- getRecordsAddedOrModified() - Method in class com.netflix.hollow.api.producer.IncrementalCycleListener.IncrementalCycleStatus
-
Deprecated.
- getRecordsRemoved() - Method in class com.netflix.hollow.api.producer.IncrementalCycleListener.IncrementalCycleStatus
-
Deprecated.
- getReferencedGenericRecord(String) - Method in class com.netflix.hollow.api.objects.generic.GenericHollowObject
-
- getReferencedType(String) - Method in class com.netflix.hollow.core.schema.HollowObjectSchema
-
- getReferencedType(int) - Method in class com.netflix.hollow.core.schema.HollowObjectSchema
-
- getReferencedTypeState(int) - Method in class com.netflix.hollow.core.schema.HollowObjectSchema
-
- getRefreshEndTimeNano() - Method in class com.netflix.hollow.api.consumer.metrics.ConsumerRefreshMetrics
-
- getRefreshFailed() - Method in class com.netflix.hollow.api.metrics.HollowConsumerMetrics
-
- getRefreshLock() - Method in class com.netflix.hollow.api.consumer.HollowConsumer
-
- getRefreshSucceded() - Method in class com.netflix.hollow.api.metrics.HollowConsumerMetrics
-
- getRefreshSuccessAgeMillisOptional() - Method in class com.netflix.hollow.api.consumer.metrics.ConsumerRefreshMetrics
-
- getRemovedRecords() - Method in class com.netflix.hollow.api.consumer.data.AbstractHollowDataAccessor
-
- getResults() - Method in class com.netflix.hollow.api.producer.validation.ValidationStatus
-
Returns the validation results.
- getResultType() - Method in class com.netflix.hollow.api.producer.validation.ValidationResult
-
Returns the validation result type.
- getReverseDeltasCompleted() - Method in class com.netflix.hollow.api.metrics.HollowProducerMetrics
-
- getReverseDeltasFailed() - Method in class com.netflix.hollow.api.metrics.HollowProducerMetrics
-
- getRootNodes() - Method in class com.netflix.hollow.api.client.StackTraceRecorder
-
- getRootType() - Method in class com.netflix.hollow.core.index.FieldPaths.FieldPath
-
Returns the root type from which this field path is bound.
- getSampler() - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowListDisabledDataAccess
-
- getSampler() - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowMapDisabledDataAccess
-
- getSampler() - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowObjectDisabledDataAccess
-
- getSampler() - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowSetDisabledDataAccess
-
- getSampler() - Method in interface com.netflix.hollow.core.read.dataaccess.HollowTypeDataAccess
-
- getSampler() - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowListMissingDataAccess
-
- getSampler() - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowMapMissingDataAccess
-
- getSampler() - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowObjectMissingDataAccess
-
- getSampler() - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowSetMissingDataAccess
-
- getSampler() - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowTypeProxyDataAccess
-
- getSampler() - Method in class com.netflix.hollow.core.read.engine.HollowTypeReadState
-
- getSampler() - Method in class com.netflix.hollow.core.read.engine.list.HollowListTypeReadState
-
- getSampler() - Method in class com.netflix.hollow.core.read.engine.map.HollowMapTypeReadState
-
- getSampler() - Method in class com.netflix.hollow.core.read.engine.object.HollowObjectTypeReadState
-
- getSampler() - Method in class com.netflix.hollow.core.read.engine.set.HollowSetTypeReadState
-
- getSampler() - Method in class com.netflix.hollow.tools.history.HollowHistoricalTypeDataAccess
-
- getSampleResults() - Method in class com.netflix.hollow.api.sampling.HollowListSampler
-
- getSampleResults() - Method in class com.netflix.hollow.api.sampling.HollowMapSampler
-
- getSampleResults() - Method in class com.netflix.hollow.api.sampling.HollowObjectCreationSampler
-
- getSampleResults() - Method in class com.netflix.hollow.api.sampling.HollowObjectSampler
-
- getSampleResults() - Method in interface com.netflix.hollow.api.sampling.HollowSampler
-
- getSampleResults() - Method in class com.netflix.hollow.api.sampling.HollowSetSampler
-
- getSamplingDirector() - Method in class com.netflix.hollow.api.custom.HollowAPI
-
- getSchema() - Method in class com.netflix.hollow.api.objects.delegate.HollowListCachedDelegate
-
- getSchema() - Method in interface com.netflix.hollow.api.objects.delegate.HollowListDelegate
-
- getSchema() - Method in class com.netflix.hollow.api.objects.delegate.HollowListLookupDelegate
-
- getSchema() - Method in class com.netflix.hollow.api.objects.delegate.HollowMapCachedDelegate
-
- getSchema() - Method in interface com.netflix.hollow.api.objects.delegate.HollowMapDelegate
-
- getSchema() - Method in class com.netflix.hollow.api.objects.delegate.HollowMapLookupDelegate
-
- getSchema() - Method in interface com.netflix.hollow.api.objects.delegate.HollowObjectDelegate
-
- getSchema() - Method in class com.netflix.hollow.api.objects.delegate.HollowObjectGenericDelegate
-
- getSchema() - Method in class com.netflix.hollow.api.objects.delegate.HollowSetCachedDelegate
-
- getSchema() - Method in interface com.netflix.hollow.api.objects.delegate.HollowSetDelegate
-
- getSchema() - Method in class com.netflix.hollow.api.objects.delegate.HollowSetLookupDelegate
-
- getSchema() - Method in class com.netflix.hollow.api.objects.HollowList
-
- getSchema() - Method in class com.netflix.hollow.api.objects.HollowMap
-
- getSchema() - Method in class com.netflix.hollow.api.objects.HollowObject
-
- getSchema() - Method in interface com.netflix.hollow.api.objects.HollowRecord
-
- getSchema() - Method in class com.netflix.hollow.api.objects.HollowSet
-
- getSchema(String) - Method in interface com.netflix.hollow.core.HollowDataset
-
- getSchema(String) - Method in interface com.netflix.hollow.core.HollowStateEngine
-
- getSchema(String) - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowDisabledDataAccess
-
- getSchema() - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowListDisabledDataAccess
-
- getSchema() - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowMapDisabledDataAccess
-
- getSchema() - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowObjectDisabledDataAccess
-
- getSchema() - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowSetDisabledDataAccess
-
- getSchema() - Method in interface com.netflix.hollow.core.read.dataaccess.HollowCollectionTypeDataAccess
-
- getSchema(String) - Method in interface com.netflix.hollow.core.read.dataaccess.HollowDataAccess
-
- getSchema() - Method in interface com.netflix.hollow.core.read.dataaccess.HollowListTypeDataAccess
-
- getSchema() - Method in interface com.netflix.hollow.core.read.dataaccess.HollowMapTypeDataAccess
-
- getSchema() - Method in interface com.netflix.hollow.core.read.dataaccess.HollowObjectTypeDataAccess
-
- getSchema() - Method in interface com.netflix.hollow.core.read.dataaccess.HollowSetTypeDataAccess
-
- getSchema() - Method in interface com.netflix.hollow.core.read.dataaccess.HollowTypeDataAccess
-
- getSchema() - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowListMissingDataAccess
-
- getSchema() - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowMapMissingDataAccess
-
- getSchema() - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowObjectMissingDataAccess
-
- getSchema() - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowSetMissingDataAccess
-
- getSchema() - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowListProxyDataAccess
-
- getSchema() - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowMapProxyDataAccess
-
- getSchema() - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowObjectProxyDataAccess
-
- getSchema(String) - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowProxyDataAccess
-
- getSchema() - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowSetProxyDataAccess
-
- getSchema() - Method in class com.netflix.hollow.core.read.engine.HollowCollectionTypeReadState
-
- getSchema(String) - Method in class com.netflix.hollow.core.read.engine.HollowReadStateEngine
-
- getSchema() - Method in class com.netflix.hollow.core.read.engine.HollowTypeReadState
-
- getSchema() - Method in class com.netflix.hollow.core.read.engine.list.HollowListTypeReadState
-
- getSchema() - Method in class com.netflix.hollow.core.read.engine.map.HollowMapTypeReadState
-
- getSchema() - Method in class com.netflix.hollow.core.read.engine.object.HollowObjectTypeReadState
-
- getSchema() - Method in class com.netflix.hollow.core.read.engine.set.HollowSetTypeReadState
-
- getSchema(String) - Method in class com.netflix.hollow.core.schema.SimpleHollowDataset
-
- getSchema() - Method in class com.netflix.hollow.core.type.delegate.BooleanDelegateCachedImpl
-
- getSchema() - Method in class com.netflix.hollow.core.type.delegate.BooleanDelegateLookupImpl
-
- getSchema() - Method in class com.netflix.hollow.core.type.delegate.DoubleDelegateCachedImpl
-
- getSchema() - Method in class com.netflix.hollow.core.type.delegate.DoubleDelegateLookupImpl
-
- getSchema() - Method in class com.netflix.hollow.core.type.delegate.FloatDelegateCachedImpl
-
- getSchema() - Method in class com.netflix.hollow.core.type.delegate.FloatDelegateLookupImpl
-
- getSchema() - Method in class com.netflix.hollow.core.type.delegate.IntegerDelegateCachedImpl
-
- getSchema() - Method in class com.netflix.hollow.core.type.delegate.IntegerDelegateLookupImpl
-
- getSchema() - Method in class com.netflix.hollow.core.type.delegate.LongDelegateCachedImpl
-
- getSchema() - Method in class com.netflix.hollow.core.type.delegate.LongDelegateLookupImpl
-
- getSchema() - Method in class com.netflix.hollow.core.type.delegate.StringDelegateCachedImpl
-
- getSchema() - Method in class com.netflix.hollow.core.type.delegate.StringDelegateLookupImpl
-
- getSchema() - Method in class com.netflix.hollow.core.write.HollowListTypeWriteState
-
- getSchema() - Method in class com.netflix.hollow.core.write.HollowMapTypeWriteState
-
- getSchema() - Method in class com.netflix.hollow.core.write.HollowObjectTypeWriteState
-
- getSchema() - Method in class com.netflix.hollow.core.write.HollowObjectWriteRecord
-
- getSchema() - Method in class com.netflix.hollow.core.write.HollowSetTypeWriteState
-
- getSchema() - Method in class com.netflix.hollow.core.write.HollowTypeWriteState
-
- getSchema(String) - Method in class com.netflix.hollow.core.write.HollowWriteStateEngine
-
- getSchema(int) - Method in interface com.netflix.hollow.core.write.objectmapper.flatrecords.HollowSchemaIdentifierMapper
-
- getSchema() - Method in class com.netflix.hollow.tools.history.HollowHistoricalListDataAccess
-
- getSchema() - Method in class com.netflix.hollow.tools.history.HollowHistoricalMapDataAccess
-
- getSchema() - Method in class com.netflix.hollow.tools.history.HollowHistoricalObjectDataAccess
-
- getSchema() - Method in class com.netflix.hollow.tools.history.HollowHistoricalSetDataAccess
-
- getSchema(String) - Method in class com.netflix.hollow.tools.history.HollowHistoricalStateDataAccess
-
- getSchema() - Method in class com.netflix.hollow.tools.history.HollowHistoricalTypeDataAccess
-
- getSchemaChanges() - Method in class com.netflix.hollow.tools.history.HollowHistoricalStateDataAccess
-
- getSchemaFieldPositionPath() - Method in class com.netflix.hollow.core.index.HollowHashIndexField
-
- getSchemaId(HollowSchema) - Method in interface com.netflix.hollow.core.write.objectmapper.flatrecords.HollowSchemaIdentifierMapper
-
- getSchemas() - Method in class com.netflix.hollow.core.HollowBlobHeader
-
- getSchemas() - Method in class com.netflix.hollow.core.HollowBlobOptionalPartHeader
-
- getSchemas() - Method in interface com.netflix.hollow.core.HollowDataset
-
- getSchemas() - Method in interface com.netflix.hollow.core.HollowStateEngine
-
- getSchemas() - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowDisabledDataAccess
-
- getSchemas() - Method in interface com.netflix.hollow.core.read.dataaccess.HollowDataAccess
-
- getSchemas() - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowProxyDataAccess
-
- getSchemas() - Method in class com.netflix.hollow.core.read.engine.HollowReadStateEngine
-
- getSchemas() - Method in class com.netflix.hollow.core.schema.SimpleHollowDataset
-
- getSchemas() - Method in class com.netflix.hollow.core.write.HollowWriteStateEngine
-
- getSchemas() - Method in class com.netflix.hollow.tools.history.HollowHistoricalStateDataAccess
-
- getSchemaType() - Method in class com.netflix.hollow.core.schema.HollowListSchema
-
- getSchemaType() - Method in class com.netflix.hollow.core.schema.HollowMapSchema
-
- getSchemaType() - Method in class com.netflix.hollow.core.schema.HollowObjectSchema
-
- getSchemaType() - Method in class com.netflix.hollow.core.schema.HollowSchema
-
- getSchemaType() - Method in class com.netflix.hollow.core.schema.HollowSetSchema
-
- getSegments() - Method in class com.netflix.hollow.core.index.FieldPaths.FieldPath
-
Returns the field segments.
- getSelectField() - Method in class com.netflix.hollow.core.index.HollowHashIndex
-
- getSelectField() - Method in class com.netflix.hollow.core.index.HollowHashIndexBuilder
-
- getSelectFieldSpec() - Method in class com.netflix.hollow.core.index.HollowPreindexer
-
- getSelectHashArray() - Method in class com.netflix.hollow.core.index.HollowHashIndex.HollowHashIndexState
-
- getSet(String) - Method in class com.netflix.hollow.api.objects.generic.GenericHollowObject
-
- getShard(HollowTypeReadState, int) - Method in interface com.netflix.hollow.tools.split.HollowSplitterCopyDirector
-
- getShard(HollowTypeReadState, int) - Method in class com.netflix.hollow.tools.split.HollowSplitterOrdinalCopyDirector
-
- getShard(HollowTypeReadState, int) - Method in class com.netflix.hollow.tools.split.HollowSplitterPrimaryKeyCopyDirector
-
- getShortcut(String) - Method in class com.netflix.hollow.api.codegen.HollowErgonomicAPIShortcuts
-
- getSnapshotsCompleted() - Method in class com.netflix.hollow.api.metrics.HollowProducerMetrics
-
- getSnapshotsFailed() - Method in class com.netflix.hollow.api.metrics.HollowProducerMetrics
-
- getSnapshotTransition() - Method in class com.netflix.hollow.api.client.HollowUpdatePlan
-
- getSpecifiedTypes() - Method in class com.netflix.hollow.core.read.filter.HollowFilterConfig
-
Deprecated.
- getStaleReferenceStackTraceRecorder() - Method in class com.netflix.hollow.api.client.StaleHollowReferenceDetector
-
- getStaleReferenceUsageStackTraceRecorder() - Method in class com.netflix.hollow.api.client.HollowClient
-
Deprecated.
- getStaleReferenceUsageStackTraceRecorder() - Method in class com.netflix.hollow.api.client.HollowClientUpdater
-
- getStateEngine() - Method in class com.netflix.hollow.api.client.HollowClient
-
Deprecated.
- getStateEngine() - Method in class com.netflix.hollow.api.client.HollowClientUpdater
-
- getStateEngine() - Method in class com.netflix.hollow.api.consumer.HollowConsumer
-
- getStateEngine() - Method in interface com.netflix.hollow.api.producer.HollowProducer.ReadState
-
Returns the read state engine
- getStateEngine() - Method in interface com.netflix.hollow.api.producer.HollowProducer.WriteState
-
- getStateEngine() - Method in class com.netflix.hollow.core.index.HollowHashIndex
-
- getStateEngine() - Method in class com.netflix.hollow.core.read.engine.HollowTypeReadState
-
- getStateEngine() - Method in class com.netflix.hollow.core.write.HollowTypeWriteState
-
- getStateEngine() - Method in class com.netflix.hollow.core.write.objectmapper.HollowObjectMapper
-
- getStateEngine() - Method in class com.netflix.hollow.tools.patch.delta.HollowStateDeltaPatcher
-
Returns the HollowWriteStateEngine containing the state, use this to write the deltas and reverse deltas.
- getStaticAPIGenerator(HollowSchema) - Method in class com.netflix.hollow.api.codegen.HollowAPIGenerator
-
- getStatus() - Method in class com.netflix.hollow.api.producer.HollowProducerListener.ProducerStatus
-
Status of the latest stage completed by HollowProducer
.
- getStatus() - Method in class com.netflix.hollow.api.producer.HollowProducerListener.PublishStatus
-
Status to indicate if publishing was successful or failed.
- getStatus() - Method in class com.netflix.hollow.api.producer.HollowProducerListener.RestoreStatus
-
Status of the restore
- getStatus() - Method in class com.netflix.hollow.api.producer.IncrementalCycleListener.IncrementalCycleStatus
-
Deprecated.
Status of the latest stage completed by HollowIncrementalProducer
.
- getStream() - Method in class com.netflix.hollow.api.producer.ProducerOptionalBlobPartConfig.ConfiguredOutputStream
-
- getStreamsByType() - Method in class com.netflix.hollow.api.producer.ProducerOptionalBlobPartConfig.OptionalBlobPartOutputStreams
-
- getString(int, String) - Method in class com.netflix.hollow.api.objects.delegate.HollowObjectAbstractDelegate
-
- getString(int, String) - Method in interface com.netflix.hollow.api.objects.delegate.HollowObjectDelegate
-
- getString(String) - Method in class com.netflix.hollow.api.objects.HollowObject
-
- getSubPackageName() - Method in class com.netflix.hollow.api.codegen.HollowConsumerJavaFileGenerator
-
- getThrowable() - Method in class com.netflix.hollow.api.producer.validation.ValidationResult
-
Returns the
Throwable
associated with a validator that
failed with an unexpected
error
.
- getToOrdinal(int) - Method in class com.netflix.hollow.tools.diff.count.HollowFieldDiff
-
- getToOrdinalIdentityTranslator() - Method in class com.netflix.hollow.tools.diff.exact.DiffEqualOrdinalMap
-
- getTopLevelTypes() - Method in interface com.netflix.hollow.tools.split.HollowSplitterCopyDirector
-
- getTopLevelTypes() - Method in class com.netflix.hollow.tools.split.HollowSplitterOrdinalCopyDirector
-
- getTopLevelTypes() - Method in class com.netflix.hollow.tools.split.HollowSplitterPrimaryKeyCopyDirector
-
- getToStateEngine() - Method in class com.netflix.hollow.tools.diff.HollowDiff
-
- getTotalDiffScore() - Method in class com.netflix.hollow.tools.diff.count.HollowFieldDiff
-
- getTotalDiffScore() - Method in class com.netflix.hollow.tools.diff.HollowTypeDiff
-
- getTotalHeapFootprint() - Method in class com.netflix.hollow.api.metrics.HollowMetrics
-
- getTotalHistory() - Method in class com.netflix.hollow.tools.history.HollowHistoricalStateDataAccess
-
- getTotalItemsInFromState() - Method in class com.netflix.hollow.tools.diff.HollowTypeDiff
-
- getTotalItemsInToState() - Method in class com.netflix.hollow.tools.diff.HollowTypeDiff
-
- getTotalMatchedEqualElements() - Method in class com.netflix.hollow.tools.diff.specific.HollowSpecificDiff
-
- getTotalModifiedElements() - Method in class com.netflix.hollow.tools.diff.specific.HollowSpecificDiff
-
- getTotalNumberOfMatches() - Method in class com.netflix.hollow.tools.diff.HollowTypeDiff
-
- getTotalPopulatedOrdinals() - Method in class com.netflix.hollow.api.metrics.HollowMetrics
-
- getTotalSizeOfAllVarLengthData() - Method in class com.netflix.hollow.core.write.FieldStatistics
-
- getTotalUnmatchedFromElements() - Method in class com.netflix.hollow.tools.diff.specific.HollowSpecificDiff
-
- getTotalUnmatchedToElements() - Method in class com.netflix.hollow.tools.diff.specific.HollowSpecificDiff
-
- getToTypeState() - Method in class com.netflix.hollow.tools.diff.HollowTypeDiff
-
- getToVersion() - Method in class com.netflix.hollow.api.client.HollowBlob
-
Deprecated.
- getToVersion() - Method in class com.netflix.hollow.api.consumer.HollowConsumer.Blob
-
- getToVersion() - Method in class com.netflix.hollow.api.producer.HollowProducer.Blob
-
- getTraceLine() - Method in class com.netflix.hollow.api.client.StackTraceRecorder.StackTraceNode
-
- getTransition(int) - Method in class com.netflix.hollow.api.client.HollowUpdatePlan
-
- getTransitions() - Method in class com.netflix.hollow.api.client.HollowUpdatePlan
-
- getTransitionSequence() - Method in class com.netflix.hollow.api.client.HollowUpdatePlan
-
- getTransitionSequence() - Method in class com.netflix.hollow.api.consumer.metrics.ConsumerRefreshMetrics.UpdatePlanDetails
-
- getTraverser() - Method in class com.netflix.hollow.core.index.HollowPreindexer
-
- getType() - Method in class com.netflix.hollow.api.codegen.HollowErgonomicAPIShortcuts.Shortcut
-
- getType() - Method in class com.netflix.hollow.api.consumer.data.AbstractHollowDataAccessor
-
- getType() - Method in enum com.netflix.hollow.api.consumer.HollowConsumer.Blob.BlobType
-
- getType() - Method in class com.netflix.hollow.api.producer.HollowProducer.Blob
-
- getType() - Method in class com.netflix.hollow.api.producer.Status
-
Gets the status type
- getType() - Method in class com.netflix.hollow.core.index.FieldPaths.ObjectFieldSegment
-
The field type of the field in the enclosing object schema.
- getType() - Method in class com.netflix.hollow.core.index.HollowHashIndex
-
- getType() - Method in class com.netflix.hollow.core.index.key.PrimaryKey
-
- getType() - Method in class com.netflix.hollow.core.write.objectmapper.RecordPrimaryKey
-
- getTypeAPI() - Method in class com.netflix.hollow.api.objects.delegate.HollowListCachedDelegate
-
- getTypeAPI() - Method in interface com.netflix.hollow.api.objects.delegate.HollowListDelegate
-
- getTypeAPI() - Method in class com.netflix.hollow.api.objects.delegate.HollowListLookupDelegate
-
- getTypeAPI() - Method in class com.netflix.hollow.api.objects.delegate.HollowMapCachedDelegate
-
- getTypeAPI() - Method in interface com.netflix.hollow.api.objects.delegate.HollowMapDelegate
-
- getTypeAPI() - Method in class com.netflix.hollow.api.objects.delegate.HollowMapLookupDelegate
-
- getTypeAPI() - Method in interface com.netflix.hollow.api.objects.delegate.HollowObjectDelegate
-
- getTypeAPI() - Method in class com.netflix.hollow.api.objects.delegate.HollowObjectGenericDelegate
-
- getTypeAPI() - Method in class com.netflix.hollow.api.objects.delegate.HollowSetCachedDelegate
-
- getTypeAPI() - Method in interface com.netflix.hollow.api.objects.delegate.HollowSetDelegate
-
- getTypeAPI() - Method in class com.netflix.hollow.api.objects.delegate.HollowSetLookupDelegate
-
- getTypeAPI() - Method in interface com.netflix.hollow.core.type.delegate.BooleanDelegate
-
- getTypeAPI() - Method in class com.netflix.hollow.core.type.delegate.BooleanDelegateCachedImpl
-
- getTypeAPI() - Method in class com.netflix.hollow.core.type.delegate.BooleanDelegateLookupImpl
-
- getTypeAPI() - Method in interface com.netflix.hollow.core.type.delegate.DoubleDelegate
-
- getTypeAPI() - Method in class com.netflix.hollow.core.type.delegate.DoubleDelegateCachedImpl
-
- getTypeAPI() - Method in class com.netflix.hollow.core.type.delegate.DoubleDelegateLookupImpl
-
- getTypeAPI() - Method in interface com.netflix.hollow.core.type.delegate.FloatDelegate
-
- getTypeAPI() - Method in class com.netflix.hollow.core.type.delegate.FloatDelegateCachedImpl
-
- getTypeAPI() - Method in class com.netflix.hollow.core.type.delegate.FloatDelegateLookupImpl
-
- getTypeAPI() - Method in interface com.netflix.hollow.core.type.delegate.IntegerDelegate
-
- getTypeAPI() - Method in class com.netflix.hollow.core.type.delegate.IntegerDelegateCachedImpl
-
- getTypeAPI() - Method in class com.netflix.hollow.core.type.delegate.IntegerDelegateLookupImpl
-
- getTypeAPI() - Method in interface com.netflix.hollow.core.type.delegate.LongDelegate
-
- getTypeAPI() - Method in class com.netflix.hollow.core.type.delegate.LongDelegateCachedImpl
-
- getTypeAPI() - Method in class com.netflix.hollow.core.type.delegate.LongDelegateLookupImpl
-
- getTypeAPI() - Method in interface com.netflix.hollow.core.type.delegate.StringDelegate
-
- getTypeAPI() - Method in class com.netflix.hollow.core.type.delegate.StringDelegateCachedImpl
-
- getTypeAPI() - Method in class com.netflix.hollow.core.type.delegate.StringDelegateLookupImpl
-
- getTypeDataAccess() - Method in class com.netflix.hollow.api.custom.HollowListTypeAPI
-
- getTypeDataAccess() - Method in class com.netflix.hollow.api.custom.HollowMapTypeAPI
-
- getTypeDataAccess() - Method in class com.netflix.hollow.api.custom.HollowObjectTypeAPI
-
- getTypeDataAccess() - Method in class com.netflix.hollow.api.custom.HollowSetTypeAPI
-
- getTypeDataAccess() - Method in class com.netflix.hollow.api.custom.HollowTypeAPI
-
- getTypeDataAccess() - Method in class com.netflix.hollow.api.objects.delegate.HollowListCachedDelegate
-
- getTypeDataAccess() - Method in interface com.netflix.hollow.api.objects.delegate.HollowListDelegate
-
- getTypeDataAccess() - Method in class com.netflix.hollow.api.objects.delegate.HollowListLookupDelegate
-
- getTypeDataAccess() - Method in class com.netflix.hollow.api.objects.delegate.HollowMapCachedDelegate
-
- getTypeDataAccess() - Method in interface com.netflix.hollow.api.objects.delegate.HollowMapDelegate
-
- getTypeDataAccess() - Method in class com.netflix.hollow.api.objects.delegate.HollowMapLookupDelegate
-
- getTypeDataAccess() - Method in interface com.netflix.hollow.api.objects.delegate.HollowObjectDelegate
-
- getTypeDataAccess() - Method in class com.netflix.hollow.api.objects.delegate.HollowObjectGenericDelegate
-
- getTypeDataAccess() - Method in class com.netflix.hollow.api.objects.delegate.HollowSetCachedDelegate
-
- getTypeDataAccess() - Method in interface com.netflix.hollow.api.objects.delegate.HollowSetDelegate
-
- getTypeDataAccess() - Method in class com.netflix.hollow.api.objects.delegate.HollowSetLookupDelegate
-
- getTypeDataAccess() - Method in class com.netflix.hollow.api.objects.HollowList
-
- getTypeDataAccess() - Method in class com.netflix.hollow.api.objects.HollowMap
-
- getTypeDataAccess() - Method in class com.netflix.hollow.api.objects.HollowObject
-
- getTypeDataAccess() - Method in interface com.netflix.hollow.api.objects.HollowRecord
-
- getTypeDataAccess() - Method in class com.netflix.hollow.api.objects.HollowSet
-
- getTypeDataAccess(String) - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowDisabledDataAccess
-
- getTypeDataAccess(String, int) - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowDisabledDataAccess
-
- getTypeDataAccess(String) - Method in interface com.netflix.hollow.core.read.dataaccess.HollowDataAccess
-
- getTypeDataAccess(String, int) - Method in interface com.netflix.hollow.core.read.dataaccess.HollowDataAccess
-
- getTypeDataAccess(String) - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowProxyDataAccess
-
- getTypeDataAccess(String, int) - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowProxyDataAccess
-
- getTypeDataAccess(String) - Method in class com.netflix.hollow.core.read.engine.HollowReadStateEngine
-
- getTypeDataAccess(String, int) - Method in class com.netflix.hollow.core.read.engine.HollowReadStateEngine
-
- getTypeDataAccess() - Method in class com.netflix.hollow.core.type.delegate.BooleanDelegateCachedImpl
-
- getTypeDataAccess() - Method in class com.netflix.hollow.core.type.delegate.BooleanDelegateLookupImpl
-
- getTypeDataAccess() - Method in class com.netflix.hollow.core.type.delegate.DoubleDelegateCachedImpl
-
- getTypeDataAccess() - Method in class com.netflix.hollow.core.type.delegate.DoubleDelegateLookupImpl
-
- getTypeDataAccess() - Method in class com.netflix.hollow.core.type.delegate.FloatDelegateCachedImpl
-
- getTypeDataAccess() - Method in class com.netflix.hollow.core.type.delegate.FloatDelegateLookupImpl
-
- getTypeDataAccess() - Method in class com.netflix.hollow.core.type.delegate.IntegerDelegateCachedImpl
-
- getTypeDataAccess() - Method in class com.netflix.hollow.core.type.delegate.IntegerDelegateLookupImpl
-
- getTypeDataAccess() - Method in class com.netflix.hollow.core.type.delegate.LongDelegateCachedImpl
-
- getTypeDataAccess() - Method in class com.netflix.hollow.core.type.delegate.LongDelegateLookupImpl
-
- getTypeDataAccess() - Method in class com.netflix.hollow.core.type.delegate.StringDelegateCachedImpl
-
- getTypeDataAccess() - Method in class com.netflix.hollow.core.type.delegate.StringDelegateLookupImpl
-
- getTypeDataAccess(String) - Method in class com.netflix.hollow.tools.history.HollowHistoricalStateDataAccess
-
- getTypeDataAccess(String, int) - Method in class com.netflix.hollow.tools.history.HollowHistoricalStateDataAccess
-
- getTypeDiff(String) - Method in class com.netflix.hollow.tools.diff.HollowDiff
-
Retrieve a diff report for a specific type in order to inspect the calculated differences
- getTypeDiffs() - Method in class com.netflix.hollow.tools.diff.HollowDiff
-
- getTypeHeapFootprint() - Method in class com.netflix.hollow.api.metrics.HollowMetrics
-
- getTypeId() - Method in enum com.netflix.hollow.core.schema.HollowSchema.SchemaType
-
- getTypeIdWithPrimaryKey() - Method in enum com.netflix.hollow.core.schema.HollowSchema.SchemaType
-
- getTypeKeyIndexes() - Method in class com.netflix.hollow.tools.history.keyindex.HollowHistoryKeyIndex
-
- getTypeMapping(String) - Method in class com.netflix.hollow.tools.history.keyindex.HollowHistoricalStateKeyOrdinalMapping
-
- getTypeMappings() - Method in class com.netflix.hollow.tools.history.keyindex.HollowHistoricalStateKeyOrdinalMapping
-
- getTypeName() - Method in exception com.netflix.hollow.api.error.IncompatibleSchemaException
-
- getTypeName() - Method in exception com.netflix.hollow.api.error.SchemaNotFoundException
-
- getTypeName() - Method in class com.netflix.hollow.core.index.FieldPaths.FieldSegment
-
Returns the schema type name associated with this segment.
- getTypeName() - Method in class com.netflix.hollow.core.write.objectmapper.HollowListTypeMapper
-
- getTypeName() - Method in class com.netflix.hollow.core.write.objectmapper.HollowMapTypeMapper
-
- getTypeName() - Method in class com.netflix.hollow.core.write.objectmapper.HollowObjectTypeMapper
-
- getTypeName() - Method in class com.netflix.hollow.core.write.objectmapper.HollowSetTypeMapper
-
- getTypeName() - Method in class com.netflix.hollow.core.write.objectmapper.HollowTypeMapper
-
- getTypeName() - Method in class com.netflix.hollow.tools.diff.HollowTypeDiff
-
- getTypeName() - Method in class com.netflix.hollow.tools.patch.record.TypeMatchSpec
-
- getTypePopulatedOrdinals() - Method in class com.netflix.hollow.api.metrics.HollowMetrics
-
- getTypes() - Method in class com.netflix.hollow.api.producer.ProducerOptionalBlobPartConfig.ConfiguredOutputStream
-
- getTypeState() - Method in class com.netflix.hollow.core.index.HollowPreindexer
-
- getTypeState() - Method in class com.netflix.hollow.core.index.HollowPrimaryKeyIndex
-
- getTypeState() - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowListDisabledDataAccess
-
- getTypeState() - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowMapDisabledDataAccess
-
- getTypeState() - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowObjectDisabledDataAccess
-
- getTypeState() - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowSetDisabledDataAccess
-
- getTypeState() - Method in interface com.netflix.hollow.core.read.dataaccess.HollowTypeDataAccess
-
Optional operation
- getTypeState() - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowListMissingDataAccess
-
- getTypeState() - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowMapMissingDataAccess
-
- getTypeState() - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowObjectMissingDataAccess
-
- getTypeState() - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowSetMissingDataAccess
-
- getTypeState() - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowTypeProxyDataAccess
-
- getTypeState(String) - Method in class com.netflix.hollow.core.read.engine.HollowReadStateEngine
-
- getTypeState() - Method in class com.netflix.hollow.core.read.engine.HollowTypeReadState
-
- getTypeState(String) - Method in class com.netflix.hollow.core.write.HollowWriteStateEngine
-
- getTypeState() - Method in class com.netflix.hollow.tools.history.HollowHistoricalTypeDataAccess
-
- getTypeStates() - Method in class com.netflix.hollow.core.read.engine.HollowReadStateEngine
-
- getTypesWithDefinedHashCodes() - Method in class com.netflix.hollow.core.read.engine.HollowReadStateEngine
-
- getTypesWithDefinedHashCodes() - Method in class com.netflix.hollow.core.util.DefaultHashCodeFinder
-
Deprecated.
- getTypesWithDefinedHashCodes() - Method in interface com.netflix.hollow.core.util.HollowObjectHashCodeFinder
-
Deprecated.
- getTypeWriteState() - Method in class com.netflix.hollow.core.write.objectmapper.HollowListTypeMapper
-
- getTypeWriteState() - Method in class com.netflix.hollow.core.write.objectmapper.HollowMapTypeMapper
-
- getTypeWriteState() - Method in class com.netflix.hollow.core.write.objectmapper.HollowObjectTypeMapper
-
- getTypeWriteState() - Method in class com.netflix.hollow.core.write.objectmapper.HollowSetTypeMapper
-
- getTypeWriteState() - Method in class com.netflix.hollow.core.write.objectmapper.HollowTypeMapper
-
- getUnderlyingArray() - Method in class com.netflix.hollow.core.memory.ByteDataArray
-
- getUnmatchedFromOrdinals() - Method in class com.netflix.hollow.tools.diff.exact.DiffEqualOrdinalFilter
-
- getUnmatchedOrdinalMapping(String) - Method in class com.netflix.hollow.tools.history.DiffEqualityMappingOrdinalRemapper
-
- getUnmatchedOrdinalsInFrom() - Method in class com.netflix.hollow.tools.diff.HollowTypeDiff
-
- getUnmatchedOrdinalsInTo() - Method in class com.netflix.hollow.tools.diff.HollowTypeDiff
-
- getUnmatchedToOrdinals() - Method in class com.netflix.hollow.tools.diff.exact.DiffEqualOrdinalFilter
-
- getUnsafe() - Static method in class com.netflix.hollow.core.memory.HollowUnsafeHandle
-
- getUnusedPreviousOrdinals() - Method in class com.netflix.hollow.core.memory.ByteArrayOrdinalMap
-
- getUpdatedRecords() - Method in class com.netflix.hollow.api.consumer.data.AbstractHollowDataAccessor
-
- getUpdatePlanDetails() - Method in class com.netflix.hollow.api.consumer.metrics.ConsumerRefreshMetrics
-
- getValidationStatus() - Method in exception com.netflix.hollow.api.producer.validation.ValidationStatusException
-
Returns the validation status.
- getValue() - Method in class com.netflix.hollow.api.codegen.ArgumentParser.ParsedArgument
-
- getValue() - Method in class com.netflix.hollow.core.read.engine.map.PotentialMatchHollowMapEntryOrdinalIteratorImpl
-
- getValue() - Method in class com.netflix.hollow.core.read.iterator.EmptyMapOrdinalIterator
-
- getValue() - Method in interface com.netflix.hollow.core.read.iterator.HollowMapEntryOrdinalIterator
-
- getValue() - Method in class com.netflix.hollow.core.read.iterator.HollowMapEntryOrdinalIteratorImpl
-
- getValue(int) - Method in class com.netflix.hollow.core.type.BooleanTypeAPI
-
- getValue(int) - Method in interface com.netflix.hollow.core.type.delegate.BooleanDelegate
-
- getValue(int) - Method in class com.netflix.hollow.core.type.delegate.BooleanDelegateCachedImpl
-
- getValue(int) - Method in class com.netflix.hollow.core.type.delegate.BooleanDelegateLookupImpl
-
- getValue(int) - Method in interface com.netflix.hollow.core.type.delegate.DoubleDelegate
-
- getValue(int) - Method in class com.netflix.hollow.core.type.delegate.DoubleDelegateCachedImpl
-
- getValue(int) - Method in class com.netflix.hollow.core.type.delegate.DoubleDelegateLookupImpl
-
- getValue(int) - Method in interface com.netflix.hollow.core.type.delegate.FloatDelegate
-
- getValue(int) - Method in class com.netflix.hollow.core.type.delegate.FloatDelegateCachedImpl
-
- getValue(int) - Method in class com.netflix.hollow.core.type.delegate.FloatDelegateLookupImpl
-
- getValue(int) - Method in interface com.netflix.hollow.core.type.delegate.IntegerDelegate
-
- getValue(int) - Method in class com.netflix.hollow.core.type.delegate.IntegerDelegateCachedImpl
-
- getValue(int) - Method in class com.netflix.hollow.core.type.delegate.IntegerDelegateLookupImpl
-
- getValue(int) - Method in interface com.netflix.hollow.core.type.delegate.LongDelegate
-
- getValue(int) - Method in class com.netflix.hollow.core.type.delegate.LongDelegateCachedImpl
-
- getValue(int) - Method in class com.netflix.hollow.core.type.delegate.LongDelegateLookupImpl
-
- getValue(int) - Method in interface com.netflix.hollow.core.type.delegate.StringDelegate
-
- getValue(int) - Method in class com.netflix.hollow.core.type.delegate.StringDelegateCachedImpl
-
- getValue(int) - Method in class com.netflix.hollow.core.type.delegate.StringDelegateLookupImpl
-
- getValue(int) - Method in class com.netflix.hollow.core.type.DoubleTypeAPI
-
- getValue(int) - Method in class com.netflix.hollow.core.type.FloatTypeAPI
-
- getValue() - Method in class com.netflix.hollow.core.type.HBoolean
-
- getValue() - Method in class com.netflix.hollow.core.type.HDouble
-
- getValue() - Method in class com.netflix.hollow.core.type.HFloat
-
- getValue() - Method in class com.netflix.hollow.core.type.HInteger
-
- getValue() - Method in class com.netflix.hollow.core.type.HLong
-
- getValue() - Method in class com.netflix.hollow.core.type.HString
-
- getValue(int) - Method in class com.netflix.hollow.core.type.IntegerTypeAPI
-
- getValue(int) - Method in class com.netflix.hollow.core.type.LongTypeAPI
-
- getValue(int) - Method in class com.netflix.hollow.core.type.StringTypeAPI
-
- getValue() - Method in class com.netflix.hollow.core.util.IntMap.IntMapEntryIterator
-
- getValueBoxed(int) - Method in class com.netflix.hollow.core.type.BooleanTypeAPI
-
- getValueBoxed(int) - Method in interface com.netflix.hollow.core.type.delegate.BooleanDelegate
-
- getValueBoxed(int) - Method in class com.netflix.hollow.core.type.delegate.BooleanDelegateCachedImpl
-
- getValueBoxed(int) - Method in class com.netflix.hollow.core.type.delegate.BooleanDelegateLookupImpl
-
- getValueBoxed(int) - Method in interface com.netflix.hollow.core.type.delegate.DoubleDelegate
-
- getValueBoxed(int) - Method in class com.netflix.hollow.core.type.delegate.DoubleDelegateCachedImpl
-
- getValueBoxed(int) - Method in class com.netflix.hollow.core.type.delegate.DoubleDelegateLookupImpl
-
- getValueBoxed(int) - Method in interface com.netflix.hollow.core.type.delegate.FloatDelegate
-
- getValueBoxed(int) - Method in class com.netflix.hollow.core.type.delegate.FloatDelegateCachedImpl
-
- getValueBoxed(int) - Method in class com.netflix.hollow.core.type.delegate.FloatDelegateLookupImpl
-
- getValueBoxed(int) - Method in interface com.netflix.hollow.core.type.delegate.IntegerDelegate
-
- getValueBoxed(int) - Method in class com.netflix.hollow.core.type.delegate.IntegerDelegateCachedImpl
-
- getValueBoxed(int) - Method in class com.netflix.hollow.core.type.delegate.IntegerDelegateLookupImpl
-
- getValueBoxed(int) - Method in interface com.netflix.hollow.core.type.delegate.LongDelegate
-
- getValueBoxed(int) - Method in class com.netflix.hollow.core.type.delegate.LongDelegateCachedImpl
-
- getValueBoxed(int) - Method in class com.netflix.hollow.core.type.delegate.LongDelegateLookupImpl
-
- getValueBoxed(int) - Method in class com.netflix.hollow.core.type.DoubleTypeAPI
-
- getValueBoxed(int) - Method in class com.netflix.hollow.core.type.FloatTypeAPI
-
- getValueBoxed() - Method in class com.netflix.hollow.core.type.HBoolean
-
- getValueBoxed() - Method in class com.netflix.hollow.core.type.HDouble
-
- getValueBoxed() - Method in class com.netflix.hollow.core.type.HFloat
-
- getValueBoxed() - Method in class com.netflix.hollow.core.type.HInteger
-
- getValueBoxed() - Method in class com.netflix.hollow.core.type.HLong
-
- getValueBoxed(int) - Method in class com.netflix.hollow.core.type.IntegerTypeAPI
-
- getValueBoxed(int) - Method in class com.netflix.hollow.core.type.LongTypeAPI
-
- getValueType() - Method in class com.netflix.hollow.core.schema.HollowMapSchema
-
- getValueTypeState() - Method in class com.netflix.hollow.core.schema.HollowMapSchema
-
- getVersion() - Method in interface com.netflix.hollow.api.producer.HollowProducer.ReadState
-
Returns the version of the read state
- getVersion() - Method in interface com.netflix.hollow.api.producer.HollowProducer.WriteState
-
Returns the version of the current producer cycle being populated.
- getVersion() - Method in class com.netflix.hollow.api.producer.HollowProducerListener.ProducerStatus
-
This version is currently under process by HollowProducer
.
- getVersion() - Method in class com.netflix.hollow.api.producer.IncrementalCycleListener.IncrementalCycleStatus
-
Deprecated.
This version is currently under process by HollowIncrementalProducer
which matches with version of HollowProducer
.
- getVersion() - Method in class com.netflix.hollow.tools.history.HollowHistoricalState
-
- getVersion() - Method in class com.netflix.hollow.tools.history.HollowHistoricalStateDataAccess
-
- getVersionReached() - Method in class com.netflix.hollow.api.producer.HollowProducerListener.RestoreStatus
-
The version reached when restoring.
- getViaFieldName() - Method in class com.netflix.hollow.tools.diff.HollowDiffNodeIdentifier
-
- getWasPrimary() - Method in class com.netflix.hollow.api.producer.enforcer.AbstractSingleProducerEnforcer
-
- getWriteEngine() - Method in class com.netflix.hollow.api.producer.HollowProducer
-
- gracePeriodMillis() - Method in class com.netflix.hollow.api.client.HollowClientMemoryConfig.SpecifiedConfig
-
Deprecated.
- gracePeriodMillis() - Method in interface com.netflix.hollow.api.consumer.HollowConsumer.ObjectLongevityConfig
-
- GrowingSegmentedLongArray - Class in com.netflix.hollow.core.index
-
- GrowingSegmentedLongArray(ArraySegmentRecycler) - Constructor for class com.netflix.hollow.core.index.GrowingSegmentedLongArray
-
- handleBoolean(String, int, String) - Method in class com.netflix.hollow.core.read.missing.DefaultMissingDataHandler
-
- handleBoolean(String, int, String) - Method in interface com.netflix.hollow.core.read.missing.MissingDataHandler
-
- handleBytes(String, int, String) - Method in class com.netflix.hollow.core.read.missing.DefaultMissingDataHandler
-
- handleBytes(String, int, String) - Method in interface com.netflix.hollow.core.read.missing.MissingDataHandler
-
- handleDouble(String, int, String) - Method in class com.netflix.hollow.core.read.missing.DefaultMissingDataHandler
-
- handleDouble(String, int, String) - Method in interface com.netflix.hollow.core.read.missing.MissingDataHandler
-
- handleFloat(String, int, String) - Method in class com.netflix.hollow.core.read.missing.DefaultMissingDataHandler
-
- handleFloat(String, int, String) - Method in interface com.netflix.hollow.core.read.missing.MissingDataHandler
-
- handleInt(String, int, String) - Method in class com.netflix.hollow.core.read.missing.DefaultMissingDataHandler
-
- handleInt(String, int, String) - Method in interface com.netflix.hollow.core.read.missing.MissingDataHandler
-
- handleIsNull(String, int, String) - Method in class com.netflix.hollow.core.read.missing.DefaultMissingDataHandler
-
- handleIsNull(String, int, String) - Method in interface com.netflix.hollow.core.read.missing.MissingDataHandler
-
- handleListElementOrdinal(String, int, int) - Method in class com.netflix.hollow.core.read.missing.DefaultMissingDataHandler
-
- handleListElementOrdinal(String, int, int) - Method in interface com.netflix.hollow.core.read.missing.MissingDataHandler
-
- handleListIterator(String, int) - Method in class com.netflix.hollow.core.read.missing.DefaultMissingDataHandler
-
- handleListIterator(String, int) - Method in interface com.netflix.hollow.core.read.missing.MissingDataHandler
-
- handleListSize(String, int) - Method in class com.netflix.hollow.core.read.missing.DefaultMissingDataHandler
-
- handleListSize(String, int) - Method in interface com.netflix.hollow.core.read.missing.MissingDataHandler
-
- handleLong(String, int, String) - Method in class com.netflix.hollow.core.read.missing.DefaultMissingDataHandler
-
- handleLong(String, int, String) - Method in interface com.netflix.hollow.core.read.missing.MissingDataHandler
-
- handleMapFindEntry(String, int, Object...) - Method in class com.netflix.hollow.core.read.missing.DefaultMissingDataHandler
-
- handleMapFindEntry(String, int, Object...) - Method in interface com.netflix.hollow.core.read.missing.MissingDataHandler
-
- handleMapFindKey(String, int, Object...) - Method in class com.netflix.hollow.core.read.missing.DefaultMissingDataHandler
-
- handleMapFindKey(String, int, Object...) - Method in interface com.netflix.hollow.core.read.missing.MissingDataHandler
-
- handleMapFindValue(String, int, Object...) - Method in class com.netflix.hollow.core.read.missing.DefaultMissingDataHandler
-
- handleMapFindValue(String, int, Object...) - Method in interface com.netflix.hollow.core.read.missing.MissingDataHandler
-
- handleMapGet(String, int, int, int) - Method in class com.netflix.hollow.core.read.missing.DefaultMissingDataHandler
-
- handleMapGet(String, int, int, int) - Method in interface com.netflix.hollow.core.read.missing.MissingDataHandler
-
- handleMapOrdinalIterator(String, int) - Method in class com.netflix.hollow.core.read.missing.DefaultMissingDataHandler
-
- handleMapOrdinalIterator(String, int) - Method in interface com.netflix.hollow.core.read.missing.MissingDataHandler
-
- handleMapPotentialMatchOrdinalIterator(String, int, int) - Method in class com.netflix.hollow.core.read.missing.DefaultMissingDataHandler
-
- handleMapPotentialMatchOrdinalIterator(String, int, int) - Method in interface com.netflix.hollow.core.read.missing.MissingDataHandler
-
- handleMapSize(String, int) - Method in class com.netflix.hollow.core.read.missing.DefaultMissingDataHandler
-
- handleMapSize(String, int) - Method in interface com.netflix.hollow.core.read.missing.MissingDataHandler
-
- handleReferencedOrdinal(String, int, String) - Method in class com.netflix.hollow.core.read.missing.DefaultMissingDataHandler
-
- handleReferencedOrdinal(String, int, String) - Method in interface com.netflix.hollow.core.read.missing.MissingDataHandler
-
- handleSchema(String) - Method in class com.netflix.hollow.core.read.missing.DefaultMissingDataHandler
-
- handleSchema(String) - Method in interface com.netflix.hollow.core.read.missing.MissingDataHandler
-
- handleSetContainsElement(String, int, int, int) - Method in class com.netflix.hollow.core.read.missing.DefaultMissingDataHandler
-
- handleSetContainsElement(String, int, int, int) - Method in interface com.netflix.hollow.core.read.missing.MissingDataHandler
-
- handleSetFindElement(String, int, Object...) - Method in class com.netflix.hollow.core.read.missing.DefaultMissingDataHandler
-
- handleSetFindElement(String, int, Object...) - Method in interface com.netflix.hollow.core.read.missing.MissingDataHandler
-
- handleSetIterator(String, int) - Method in class com.netflix.hollow.core.read.missing.DefaultMissingDataHandler
-
- handleSetIterator(String, int) - Method in interface com.netflix.hollow.core.read.missing.MissingDataHandler
-
- handleSetPotentialMatchIterator(String, int, int) - Method in class com.netflix.hollow.core.read.missing.DefaultMissingDataHandler
-
- handleSetPotentialMatchIterator(String, int, int) - Method in interface com.netflix.hollow.core.read.missing.MissingDataHandler
-
- handleSetSize(String, int) - Method in class com.netflix.hollow.core.read.missing.DefaultMissingDataHandler
-
- handleSetSize(String, int) - Method in interface com.netflix.hollow.core.read.missing.MissingDataHandler
-
- handleString(String, int, String) - Method in class com.netflix.hollow.core.read.missing.DefaultMissingDataHandler
-
- handleString(String, int, String) - Method in interface com.netflix.hollow.core.read.missing.MissingDataHandler
-
- handleStringEquals(String, int, String, String) - Method in class com.netflix.hollow.core.read.missing.DefaultMissingDataHandler
-
- handleStringEquals(String, int, String, String) - Method in interface com.netflix.hollow.core.read.missing.MissingDataHandler
-
- hasAnyData() - Method in class com.netflix.hollow.tools.diff.HollowTypeDiff
-
- hasChangedSinceLastCycle() - Method in class com.netflix.hollow.core.write.HollowTypeWriteState
-
- hasChangedSinceLastCycle() - Method in class com.netflix.hollow.core.write.HollowWriteStateEngine
-
- hasChanges() - Method in class com.netflix.hollow.api.producer.HollowIncrementalProducer
-
Deprecated.
- hasCollectionsInDataSet - Variable in class com.netflix.hollow.api.codegen.HollowAPIGenerator
-
- hasCollectionsInDataSet(HollowDataset) - Static method in class com.netflix.hollow.api.codegen.HollowAPIGenerator
-
Determines whether DataSet contains any collections schema
- hash(Object) - Method in class com.netflix.hollow.core.index.key.PrimaryKeyValueHasher
-
- hash(Object...) - Method in class com.netflix.hollow.core.index.key.PrimaryKeyValueHasher
-
- hash(Object[], HollowObjectSchema.FieldType[]) - Static method in class com.netflix.hollow.core.read.engine.SetMapKeyHasher
-
Hash a key
- hash(Object, HollowObjectSchema.FieldType) - Static method in class com.netflix.hollow.core.read.engine.SetMapKeyHasher
-
Hash a single key field
- HASH_TABLE_MAX_SIZE - Static variable in interface com.netflix.hollow.core.HollowConstants
-
The maximum number of buckets allowed in a Hollow hash table.
- hashCode() - Method in class com.netflix.hollow.api.codegen.CodeGeneratorConfig
-
- hashCode() - Method in class com.netflix.hollow.api.consumer.data.AbstractHollowDataAccessor.UpdatedRecord
-
- hashCode() - Method in class com.netflix.hollow.api.objects.HollowObject
-
- hashCode() - Method in class com.netflix.hollow.api.producer.validation.DuplicateDataDetectionValidator
-
- hashCode() - Method in class com.netflix.hollow.core.HollowBlobHeader
-
- hashCode() - Method in class com.netflix.hollow.core.index.FieldPaths.FieldPath
-
- hashCode() - Method in class com.netflix.hollow.core.index.FieldPaths.FieldSegment
-
- hashCode() - Method in class com.netflix.hollow.core.index.FieldPaths.ObjectFieldSegment
-
- hashCode() - Method in class com.netflix.hollow.core.index.key.PrimaryKey
-
- hashCode(ByteDataArray) - Static method in class com.netflix.hollow.core.memory.encoding.HashCodes
-
- hashCode(String) - Static method in class com.netflix.hollow.core.memory.encoding.HashCodes
-
- hashCode(byte[]) - Static method in class com.netflix.hollow.core.memory.encoding.HashCodes
-
- hashCode(ByteData, long, int) - Static method in class com.netflix.hollow.core.memory.encoding.HashCodes
-
MurmurHash3.
- hashCode() - Method in class com.netflix.hollow.core.memory.ThreadSafeBitSet
-
- hashCode() - Method in class com.netflix.hollow.core.schema.HollowListSchema
-
- hashCode() - Method in class com.netflix.hollow.core.schema.HollowMapSchema
-
- hashCode() - Method in class com.netflix.hollow.core.schema.HollowObjectSchema
-
- hashCode() - Method in class com.netflix.hollow.core.schema.HollowSetSchema
-
- hashCode(int, Object) - Method in class com.netflix.hollow.core.util.DefaultHashCodeFinder
-
Deprecated.
- hashCode(Object) - Method in class com.netflix.hollow.core.util.DefaultHashCodeFinder
-
Deprecated.
- hashCode(String, int, Object) - Method in class com.netflix.hollow.core.util.DefaultHashCodeFinder
-
Deprecated.
- hashCode(String, Object) - Method in class com.netflix.hollow.core.util.DefaultHashCodeFinder
-
Deprecated.
- hashCode(Object) - Method in interface com.netflix.hollow.core.util.HollowObjectHashCodeFinder
-
Deprecated.
For look-up at runtime.
- hashCode(String, int, Object) - Method in interface com.netflix.hollow.core.util.HollowObjectHashCodeFinder
-
Deprecated.
For serialization.
- hashCode(int, Object) - Method in interface com.netflix.hollow.core.util.HollowObjectHashCodeFinder
-
Deprecated.
- hashCode() - Method in class com.netflix.hollow.core.util.IntList
-
- hashCode() - Method in class com.netflix.hollow.core.util.LongList
-
- hashCode() - Method in class com.netflix.hollow.core.write.objectmapper.RecordPrimaryKey
-
- hashCode() - Method in class com.netflix.hollow.tools.checksum.HollowChecksum
-
- hashCode() - Method in class com.netflix.hollow.tools.diff.HollowDiffNodeIdentifier
-
- hashCodeFinder - Variable in class com.netflix.hollow.api.consumer.HollowConsumer.Builder
-
- HashCodes - Class in com.netflix.hollow.core.memory.encoding
-
- HashCodes() - Constructor for class com.netflix.hollow.core.memory.encoding.HashCodes
-
- hashElement(Object, int) - Method in class com.netflix.hollow.core.index.key.PrimaryKeyValueHasher
-
- HashIndex<T extends HollowRecord,Q> - Class in com.netflix.hollow.api.consumer.index
-
A type safe hash index for indexing non-primary-key data.
- HashIndex.Builder<T extends HollowRecord> - Class in com.netflix.hollow.api.consumer.index
-
- HashIndexSelect<T extends HollowRecord,S extends HollowRecord,Q> - Class in com.netflix.hollow.api.consumer.index
-
A type safe hash index, with result selection, for indexing non-primary-key data.
- HashIndexSelect.BuilderWithSelect<T extends HollowRecord,S extends HollowRecord> - Class in com.netflix.hollow.api.consumer.index
-
- hashInt(int) - Static method in class com.netflix.hollow.core.memory.encoding.HashCodes
-
- hashKey(String, Object[]) - Method in class com.netflix.hollow.tools.split.HollowSplitterPrimaryKeyCopyDirector
-
- hashLong(long) - Static method in class com.netflix.hollow.core.memory.encoding.HashCodes
-
- hashRecordKeys() - Method in class com.netflix.hollow.tools.history.keyindex.HollowHistoryTypeKeyIndex
-
- hashTableSize(int) - Static method in class com.netflix.hollow.core.memory.encoding.HashCodes
-
Determine size of hash table capable of storing the specified number of elements with a load
factor applied.
- hashToOrdinals() - Method in class com.netflix.hollow.tools.diff.exact.mapper.DiffEqualityTypeMapper
-
- hasIdenticalSchemas(HollowDataset) - Method in interface com.netflix.hollow.core.HollowDataset
-
- hasKey(int) - Static method in enum com.netflix.hollow.core.schema.HollowSchema.SchemaType
-
- hasMatchPaths() - Method in class com.netflix.hollow.tools.diff.HollowTypeDiff
-
Indicate whether Match Paths are defined
- hasMetadata() - Method in class com.netflix.hollow.api.producer.HollowIncrementalProducer
-
Deprecated.
- hasNext() - Method in class com.netflix.hollow.core.util.BitSetIterator
-
- hasNext() - Method in class com.netflix.hollow.tools.diff.exact.DiffEqualOrdinalMap.EmptyMatchIterator
-
- hasNext() - Method in interface com.netflix.hollow.tools.diff.exact.DiffEqualOrdinalMap.MatchIterator
-
- hasNext() - Method in class com.netflix.hollow.tools.diff.exact.DiffEqualOrdinalMap.PivotedMatchIterator
-
- hasNext() - Method in class com.netflix.hollow.tools.diff.exact.DiffEqualOrdinalMap.SingleMatchIterator
-
- hasPriorState() - Method in class com.netflix.hollow.api.consumer.data.AbstractHollowDataAccessor
-
Indicate whether Data Accessor contains prior state
NOTE: This is critical since loading a Snapshot will not contain any information about changes from prior state
- hasSampleResults() - Method in class com.netflix.hollow.api.sampling.HollowListSampler
-
- hasSampleResults() - Method in class com.netflix.hollow.api.sampling.HollowMapSampler
-
- hasSampleResults() - Method in class com.netflix.hollow.api.sampling.HollowObjectCreationSampler
-
- hasSampleResults() - Method in class com.netflix.hollow.api.sampling.HollowObjectSampler
-
- hasSampleResults() - Method in interface com.netflix.hollow.api.sampling.HollowSampler
-
- hasSampleResults() - Method in class com.netflix.hollow.api.sampling.HollowSetSampler
-
- hasSampleResults() - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowDisabledDataAccess
-
- hasSampleResults() - Method in interface com.netflix.hollow.core.read.dataaccess.HollowDataAccess
-
- hasSampleResults() - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowProxyDataAccess
-
- hasSampleResults() - Method in class com.netflix.hollow.core.read.engine.HollowReadStateEngine
-
- hasSampleResults() - Method in class com.netflix.hollow.tools.history.HollowHistoricalStateDataAccess
-
- HBoolean - Class in com.netflix.hollow.core.type
-
- HBoolean(BooleanDelegate, int) - Constructor for class com.netflix.hollow.core.type.HBoolean
-
- HDouble - Class in com.netflix.hollow.core.type
-
- HDouble(DoubleDelegate, int) - Constructor for class com.netflix.hollow.core.type.HDouble
-
- HEADER_TAG_METRIC_CYCLE_START - Static variable in interface com.netflix.hollow.core.HollowStateEngine
-
A header tag indicating the timestamp in milliseconds of when the producer cycle started
for this state engine.
- HEADER_TAG_SCHEMA_CHANGE - Static variable in interface com.netflix.hollow.core.HollowStateEngine
-
A header tag indicating that the schema has changed from that of the prior version.
- HFloat - Class in com.netflix.hollow.core.type
-
- HFloat(FloatDelegate, int) - Constructor for class com.netflix.hollow.core.type.HFloat
-
- HInteger - Class in com.netflix.hollow.core.type
-
- HInteger(IntegerDelegate, int) - Constructor for class com.netflix.hollow.core.type.HInteger
-
- hintUnmatchedOrdinalCount(String, int) - Method in class com.netflix.hollow.tools.history.DiffEqualityMappingOrdinalRemapper
-
- HistoricalPrimaryKeyMatcher - Class in com.netflix.hollow.tools.history
-
- HistoricalPrimaryKeyMatcher(HollowDataAccess, PrimaryKey) - Constructor for class com.netflix.hollow.tools.history.HistoricalPrimaryKeyMatcher
-
- HLong - Class in com.netflix.hollow.core.type
-
- HLong(LongDelegate, int) - Constructor for class com.netflix.hollow.core.type.HLong
-
- Hollow - Class in com.netflix.hollow
-
- HOLLOW_BLOB_PART_VERSION_HEADER - Static variable in class com.netflix.hollow.core.HollowBlobOptionalPartHeader
-
- HOLLOW_BLOB_VERSION_HEADER - Static variable in class com.netflix.hollow.core.HollowBlobHeader
-
- HollowAnnouncementWatcher - Class in com.netflix.hollow.api.client
-
- HollowAnnouncementWatcher() - Constructor for class com.netflix.hollow.api.client.HollowAnnouncementWatcher
-
Deprecated.
Construct a HollowAnnouncementWatcher with a default ExecutorService.
- HollowAnnouncementWatcher(ExecutorService) - Constructor for class com.netflix.hollow.api.client.HollowAnnouncementWatcher
-
Deprecated.
Construct a HollowAnnouncementWatcher with the specified ExecutorService.
- HollowAnnouncementWatcher.DefaultWatcher - Class in com.netflix.hollow.api.client
-
Deprecated.
- HollowAPI - Class in com.netflix.hollow.api.custom
-
A HollowAPI wraps a HollowDataAccess.
- HollowAPI(HollowDataAccess) - Constructor for class com.netflix.hollow.api.custom.HollowAPI
-
- HollowAPIClassJavaGenerator - Class in com.netflix.hollow.api.codegen
-
This class contains template logic for generating a
HollowAPI
implementation.
- HollowAPIClassJavaGenerator(String, String, HollowDataset, boolean, CodeGeneratorConfig) - Constructor for class com.netflix.hollow.api.codegen.HollowAPIClassJavaGenerator
-
- HollowAPIFactory - Interface in com.netflix.hollow.api.client
-
An interface which can be implemented and passed to a
HollowClient
to inject the
HollowAPI
creation behavior.
- HollowAPIFactory.ForGeneratedAPI<T extends HollowAPI> - Class in com.netflix.hollow.api.client
-
- HollowAPIFactoryJavaGenerator - Class in com.netflix.hollow.api.codegen
-
This class contains template logic for generating a
HollowAPIFactory
implementation.
- HollowAPIFactoryJavaGenerator(String, String, HollowDataset, CodeGeneratorConfig) - Constructor for class com.netflix.hollow.api.codegen.HollowAPIFactoryJavaGenerator
-
- HollowAPIGenerator - Class in com.netflix.hollow.api.codegen
-
This class is used to generate java code which defines an implementation of a
HollowAPI
.
- HollowAPIGenerator(String, String, HollowDataset) - Constructor for class com.netflix.hollow.api.codegen.HollowAPIGenerator
-
- HollowAPIGenerator(String, String, HollowDataset, Path) - Constructor for class com.netflix.hollow.api.codegen.HollowAPIGenerator
-
- HollowAPIGenerator(String, String, HollowDataset, boolean) - Constructor for class com.netflix.hollow.api.codegen.HollowAPIGenerator
-
- HollowAPIGenerator(String, String, HollowDataset, boolean, Path) - Constructor for class com.netflix.hollow.api.codegen.HollowAPIGenerator
-
- HollowAPIGenerator(String, String, HollowDataset, Set<String>) - Constructor for class com.netflix.hollow.api.codegen.HollowAPIGenerator
-
- HollowAPIGenerator(String, String, HollowDataset, Set<String>, Path) - Constructor for class com.netflix.hollow.api.codegen.HollowAPIGenerator
-
- HollowAPIGenerator(String, String, HollowDataset, Set<String>, boolean, boolean) - Constructor for class com.netflix.hollow.api.codegen.HollowAPIGenerator
-
- HollowAPIGenerator(String, String, HollowDataset, Set<String>, boolean, boolean, Path) - Constructor for class com.netflix.hollow.api.codegen.HollowAPIGenerator
-
- HollowAPIGenerator.Builder - Class in com.netflix.hollow.api.codegen
-
- HollowAPIGenerator.GeneratorArguments - Enum in com.netflix.hollow.api.codegen
-
An enumeration of possible arguments to the code generator when being called via the main
function.
- HollowBlob - Class in com.netflix.hollow.api.client
-
- HollowBlob(long) - Constructor for class com.netflix.hollow.api.client.HollowBlob
-
Deprecated.
Instantiate a snapshot to a specified data state version.
- HollowBlob(long, long) - Constructor for class com.netflix.hollow.api.client.HollowBlob
-
Deprecated.
Instantiate a delta from one data state version to another.
- HollowBlobHeader - Class in com.netflix.hollow.core
-
Represents the header of a serialized blob.
- HollowBlobHeader() - Constructor for class com.netflix.hollow.core.HollowBlobHeader
-
- HollowBlobHeaderReader - Class in com.netflix.hollow.core.read.engine
-
Contains serialization logic for the hollow blob headers.
- HollowBlobHeaderReader() - Constructor for class com.netflix.hollow.core.read.engine.HollowBlobHeaderReader
-
- HollowBlobHeaderWriter - Class in com.netflix.hollow.core.write
-
- HollowBlobHeaderWriter() - Constructor for class com.netflix.hollow.core.write.HollowBlobHeaderWriter
-
- HollowBlobInput - Class in com.netflix.hollow.core.read
-
This class provides an abstraction to help navigate between use of DataInputStream or RandomAccessFile
as the underlying resource for Hollow Producer/Consumer Blob to support the different memory modes.
- HollowBlobOptionalPartHeader - Class in com.netflix.hollow.core
-
- HollowBlobOptionalPartHeader(String) - Constructor for class com.netflix.hollow.core.HollowBlobOptionalPartHeader
-
- HollowBlobReader - Class in com.netflix.hollow.core.read.engine
-
A HollowBlobReader is used to populate and update data in a
HollowReadStateEngine
, via the consumption
of snapshot and delta blobs.
- HollowBlobReader(HollowReadStateEngine) - Constructor for class com.netflix.hollow.core.read.engine.HollowBlobReader
-
- HollowBlobReader(HollowReadStateEngine, HollowBlobHeaderReader) - Constructor for class com.netflix.hollow.core.read.engine.HollowBlobReader
-
- HollowBlobReader(HollowReadStateEngine, MemoryMode) - Constructor for class com.netflix.hollow.core.read.engine.HollowBlobReader
-
- HollowBlobReader(HollowReadStateEngine, HollowBlobHeaderReader, MemoryMode) - Constructor for class com.netflix.hollow.core.read.engine.HollowBlobReader
-
- HollowBlobRetriever - Interface in com.netflix.hollow.api.client
-
- HollowBlobWriter - Class in com.netflix.hollow.core.write
-
- HollowBlobWriter(HollowWriteStateEngine) - Constructor for class com.netflix.hollow.core.write.HollowBlobWriter
-
- HollowCachedDelegate - Interface in com.netflix.hollow.api.objects.delegate
-
- HollowChecksum - Class in com.netflix.hollow.tools.checksum
-
- HollowChecksum() - Constructor for class com.netflix.hollow.tools.checksum.HollowChecksum
-
- HollowClient - Class in com.netflix.hollow.api.client
-
- HollowClient(HollowBlobRetriever) - Constructor for class com.netflix.hollow.api.client.HollowClient
-
Deprecated.
- HollowClient(HollowBlobRetriever, HollowAnnouncementWatcher, HollowUpdateListener, HollowAPIFactory, HollowClientMemoryConfig) - Constructor for class com.netflix.hollow.api.client.HollowClient
-
Deprecated.
- HollowClient(HollowBlobRetriever, HollowAnnouncementWatcher, HollowUpdateListener, HollowAPIFactory, HollowObjectHashCodeFinder, HollowClientMemoryConfig) - Constructor for class com.netflix.hollow.api.client.HollowClient
-
Deprecated.
- HollowClient.Builder - Class in com.netflix.hollow.api.client
-
Deprecated.
- HollowClientMemoryConfig - Interface in com.netflix.hollow.api.client
-
- HollowClientMemoryConfig.SpecifiedConfig - Class in com.netflix.hollow.api.client
-
Deprecated.
- HollowClientUpdater - Class in com.netflix.hollow.api.client
-
- HollowClientUpdater(HollowConsumer.BlobRetriever, List<HollowConsumer.RefreshListener>, HollowAPIFactory, HollowConsumer.DoubleSnapshotConfig, HollowObjectHashCodeFinder, MemoryMode, HollowConsumer.ObjectLongevityConfig, HollowConsumer.ObjectLongevityDetector, HollowConsumerMetrics, HollowMetricsCollector<HollowConsumerMetrics>) - Constructor for class com.netflix.hollow.api.client.HollowClientUpdater
-
- HollowCodeGenerationUtils - Class in com.netflix.hollow.api.codegen
-
- HollowCodeGenerationUtils() - Constructor for class com.netflix.hollow.api.codegen.HollowCodeGenerationUtils
-
- HollowCollectionSchema - Class in com.netflix.hollow.core.schema
-
- HollowCollectionSchema(String) - Constructor for class com.netflix.hollow.core.schema.HollowCollectionSchema
-
- HollowCollectionsGenerator - Class in com.netflix.hollow.api.codegen.objects
-
- HollowCollectionsGenerator(String, String, HollowSchema, HollowDataset, CodeGeneratorConfig) - Constructor for class com.netflix.hollow.api.codegen.objects.HollowCollectionsGenerator
-
- HollowCollectionTypeDataAccess - Interface in com.netflix.hollow.core.read.dataaccess
-
A handle for all of the records of a specific LIST or SET type in a Hollow dataset.
- HollowCollectionTypeReadState - Class in com.netflix.hollow.core.read.engine
-
- HollowCollectionTypeReadState(HollowReadStateEngine, MemoryMode, HollowSchema) - Constructor for class com.netflix.hollow.core.read.engine.HollowCollectionTypeReadState
-
- HollowCombiner - Class in com.netflix.hollow.tools.combine
-
- HollowCombiner(HollowReadStateEngine...) - Constructor for class com.netflix.hollow.tools.combine.HollowCombiner
-
- HollowCombiner(HollowCombinerCopyDirector, HollowReadStateEngine...) - Constructor for class com.netflix.hollow.tools.combine.HollowCombiner
-
- HollowCombiner(HollowWriteStateEngine, HollowReadStateEngine...) - Constructor for class com.netflix.hollow.tools.combine.HollowCombiner
-
- HollowCombiner(HollowCombinerCopyDirector, HollowWriteStateEngine, HollowReadStateEngine...) - Constructor for class com.netflix.hollow.tools.combine.HollowCombiner
-
- HollowCombinerCopyDirector - Interface in com.netflix.hollow.tools.combine
-
Specifies specific records (via their ordinals) to include/exclude while copying.
- HollowCombinerExcludeOrdinalsCopyDirector - Class in com.netflix.hollow.tools.combine
-
An implementation of
HollowCombinerCopyDirector
which specifies the ordinals to
include in the
copy operation for a single state engine.
- HollowCombinerExcludeOrdinalsCopyDirector(Map<String, BitSet>) - Constructor for class com.netflix.hollow.tools.combine.HollowCombinerExcludeOrdinalsCopyDirector
-
- HollowCombinerExcludePrimaryKeysCopyDirector - Class in com.netflix.hollow.tools.combine
-
Specifies a set of exclusions for a
HollowCombiner
's operation over one or more inputs.
- HollowCombinerExcludePrimaryKeysCopyDirector() - Constructor for class com.netflix.hollow.tools.combine.HollowCombinerExcludePrimaryKeysCopyDirector
-
- HollowCombinerExcludePrimaryKeysCopyDirector(HollowCombinerCopyDirector) - Constructor for class com.netflix.hollow.tools.combine.HollowCombinerExcludePrimaryKeysCopyDirector
-
- HollowCombinerIncludeOrdinalsCopyDirector - Class in com.netflix.hollow.tools.combine
-
An implementation of
HollowCombinerCopyDirector
which specifies the ordinals to
include in the
copy operation for a single state engine.
- HollowCombinerIncludeOrdinalsCopyDirector(Map<String, BitSet>) - Constructor for class com.netflix.hollow.tools.combine.HollowCombinerIncludeOrdinalsCopyDirector
-
- HollowCombinerIncludePrimaryKeysCopyDirector - Class in com.netflix.hollow.tools.combine
-
Specifies a set of inclusions for a
HollowCombiner
's operation over one or more inputs.
- HollowCombinerIncludePrimaryKeysCopyDirector() - Constructor for class com.netflix.hollow.tools.combine.HollowCombinerIncludePrimaryKeysCopyDirector
-
- HollowCombinerIncludePrimaryKeysCopyDirector(HollowCombinerCopyDirector) - Constructor for class com.netflix.hollow.tools.combine.HollowCombinerIncludePrimaryKeysCopyDirector
-
- HollowCombinerOrdinalRemapper - Class in com.netflix.hollow.tools.combine
-
Used by the
HollowCombiner
to track the mapping between ordinals in the input state and ordinals in the output state.
- HollowCombinerOrdinalRemapper(HollowCombiner, HollowReadStateEngine) - Constructor for class com.netflix.hollow.tools.combine.HollowCombinerOrdinalRemapper
-
- HollowCompactor - Class in com.netflix.hollow.tools.compact
-
During a long delta chain, it's possible that a large number of holes in the ordinal space will exist in some types.
- HollowCompactor(HollowWriteStateEngine, HollowReadStateEngine, HollowCompactor.CompactionConfig) - Constructor for class com.netflix.hollow.tools.compact.HollowCompactor
-
Provide the state engines on which to operate, and the criteria to identify when a compaction is necessary
- HollowCompactor(HollowWriteStateEngine, HollowReadStateEngine, long, int) - Constructor for class com.netflix.hollow.tools.compact.HollowCompactor
-
Provide the state engines on which to operate, and the criteria to identify when a compaction is necessary
- HollowCompactor.CompactionConfig - Class in com.netflix.hollow.tools.compact
-
A configuration that specifies when a type is a candidate for compaction.
- HollowConstants - Interface in com.netflix.hollow.core
-
An interface to gather various sentinel constants used across hollow.
- HollowConsumer - Class in com.netflix.hollow.api.consumer
-
A HollowConsumer is the top-level class used by consumers of Hollow data to initialize and keep up-to-date a local in-memory
copy of a hollow dataset.
- HollowConsumer(HollowConsumer.BlobRetriever, HollowConsumer.AnnouncementWatcher, List<HollowConsumer.RefreshListener>, HollowAPIFactory, HollowFilterConfig, HollowConsumer.ObjectLongevityConfig, HollowConsumer.ObjectLongevityDetector, HollowConsumer.DoubleSnapshotConfig, HollowObjectHashCodeFinder, Executor, MemoryMode) - Constructor for class com.netflix.hollow.api.consumer.HollowConsumer
-
- HollowConsumer(HollowConsumer.BlobRetriever, HollowConsumer.AnnouncementWatcher, List<HollowConsumer.RefreshListener>, HollowAPIFactory, HollowFilterConfig, HollowConsumer.ObjectLongevityConfig, HollowConsumer.ObjectLongevityDetector, HollowConsumer.DoubleSnapshotConfig, HollowObjectHashCodeFinder, Executor, MemoryMode, HollowMetricsCollector<HollowConsumerMetrics>) - Constructor for class com.netflix.hollow.api.consumer.HollowConsumer
-
- HollowConsumer(B) - Constructor for class com.netflix.hollow.api.consumer.HollowConsumer
-
- HollowConsumer.AbstractRefreshListener - Class in com.netflix.hollow.api.consumer
-
- HollowConsumer.AnnouncementWatcher - Interface in com.netflix.hollow.api.consumer
-
Implementations of this class are responsible for two things:
- HollowConsumer.Blob - Class in com.netflix.hollow.api.consumer
-
A Blob, which is either a snapshot or a delta, defines three things:
The "from" version
The unique identifier of the state to which a delta transition should be applied.
- HollowConsumer.Blob.BlobType - Enum in com.netflix.hollow.api.consumer
-
Blobs can be of types SNAPSHOT
, DELTA
or REVERSE_DELTA
.
- HollowConsumer.BlobRetriever - Interface in com.netflix.hollow.api.consumer
-
An interface which defines the necessary interactions of Hollow with a blob data store.
- HollowConsumer.Builder<B extends HollowConsumer.Builder<B>> - Class in com.netflix.hollow.api.consumer
-
- HollowConsumer.DoubleSnapshotConfig - Interface in com.netflix.hollow.api.consumer
-
- HollowConsumer.ObjectLongevityConfig - Interface in com.netflix.hollow.api.consumer
-
- HollowConsumer.ObjectLongevityDetector - Interface in com.netflix.hollow.api.consumer
-
Listens for stale Hollow object usage
- HollowConsumer.RefreshListener - Interface in com.netflix.hollow.api.consumer
-
Implementations of this class will define what to do when various events happen before, during, and after updating
local in-memory copies of hollow data sets.
- HollowConsumer.RefreshRegistrationListener - Interface in com.netflix.hollow.api.consumer
-
A listener of refresh listener addition and removal.
- HollowConsumer.TransitionAwareRefreshListener - Interface in com.netflix.hollow.api.consumer
-
- HollowConsumerAPI - Interface in com.netflix.hollow.api.consumer
-
- HollowConsumerAPI.BooleanRetriever - Interface in com.netflix.hollow.api.consumer
-
- HollowConsumerAPI.DoubleRetriever - Interface in com.netflix.hollow.api.consumer
-
- HollowConsumerAPI.FloatRetriever - Interface in com.netflix.hollow.api.consumer
-
- HollowConsumerAPI.IntegerRetriever - Interface in com.netflix.hollow.api.consumer
-
- HollowConsumerAPI.LongRetriever - Interface in com.netflix.hollow.api.consumer
-
- HollowConsumerAPI.StringRetriever - Interface in com.netflix.hollow.api.consumer
-
- HollowConsumerJavaFileGenerator - Class in com.netflix.hollow.api.codegen
-
Not intended for external consumption.
- HollowConsumerJavaFileGenerator(String, String, HollowDataset, CodeGeneratorConfig) - Constructor for class com.netflix.hollow.api.codegen.HollowConsumerJavaFileGenerator
-
- HollowConsumerMetrics - Class in com.netflix.hollow.api.metrics
-
- HollowConsumerMetrics() - Constructor for class com.netflix.hollow.api.metrics.HollowConsumerMetrics
-
- HollowDataAccess - Interface in com.netflix.hollow.core.read.dataaccess
-
- HollowDataAccessorGenerator - Class in com.netflix.hollow.api.codegen.api
-
This class contains template logic for generating a
HollowAPI
implementation.
- HollowDataAccessorGenerator(String, String, HollowObjectSchema, HollowDataset, CodeGeneratorConfig) - Constructor for class com.netflix.hollow.api.codegen.api.HollowDataAccessorGenerator
-
- HollowDataset - Interface in com.netflix.hollow.core
-
A Hollow dataset contains a set of strongly typed schemas.
- HollowDiff - Class in com.netflix.hollow.tools.diff
-
Calculate a detailed accounting for the differences between two data states.
- HollowDiff(HollowReadStateEngine, HollowReadStateEngine) - Constructor for class com.netflix.hollow.tools.diff.HollowDiff
-
Instantiate a HollowDiff.
- HollowDiff(HollowReadStateEngine, HollowReadStateEngine, boolean) - Constructor for class com.netflix.hollow.tools.diff.HollowDiff
-
Instantiate a HollowDiff.
- HollowDiff(HollowReadStateEngine, HollowReadStateEngine, boolean, boolean) - Constructor for class com.netflix.hollow.tools.diff.HollowDiff
-
Instantiate a HollowDiff.
- HollowDiffCollectionCountingNode - Class in com.netflix.hollow.tools.diff.count
-
Counting nodes are used by the HollowDiff to count and aggregate changes for specific record types in a data model.
- HollowDiffCollectionCountingNode(HollowDiff, HollowTypeDiff, HollowDiffNodeIdentifier, HollowCollectionTypeReadState, HollowCollectionTypeReadState) - Constructor for class com.netflix.hollow.tools.diff.count.HollowDiffCollectionCountingNode
-
- HollowDiffCountingNode - Class in com.netflix.hollow.tools.diff.count
-
Counting nodes are used by the HollowDiff to count and aggregate changes for specific record types in a data model.
- HollowDiffCountingNode(HollowDiff, HollowTypeDiff, HollowDiffNodeIdentifier) - Constructor for class com.netflix.hollow.tools.diff.count.HollowDiffCountingNode
-
- HollowDiffFieldCountingNode - Class in com.netflix.hollow.tools.diff.count
-
Counting nodes are used by the HollowDiff to count and aggregate changes for specific record types in a data model.
- HollowDiffFieldCountingNode(HollowDiff, HollowTypeDiff, HollowDiffNodeIdentifier, HollowObjectTypeReadState, HollowObjectTypeReadState, HollowObjectSchema, int) - Constructor for class com.netflix.hollow.tools.diff.count.HollowDiffFieldCountingNode
-
- HollowDiffMapCountingNode - Class in com.netflix.hollow.tools.diff.count
-
Counting nodes are used by the HollowDiff to count and aggregate changes for specific record types in a data model.
- HollowDiffMapCountingNode(HollowDiff, HollowTypeDiff, HollowDiffNodeIdentifier, HollowMapTypeReadState, HollowMapTypeReadState) - Constructor for class com.netflix.hollow.tools.diff.count.HollowDiffMapCountingNode
-
- HollowDiffMatcher - Class in com.netflix.hollow.tools.diff
-
Intended for use in the context of a HollowDiff.
- HollowDiffMatcher(HollowObjectTypeReadState, HollowObjectTypeReadState) - Constructor for class com.netflix.hollow.tools.diff.HollowDiffMatcher
-
- HollowDiffMissingCountingNode - Class in com.netflix.hollow.tools.diff.count
-
Counting nodes are used by the HollowDiff to count and aggregate changes for specific record types in a data model.
- HollowDiffMissingCountingNode(HollowDiff, HollowTypeDiff, HollowDiffNodeIdentifier) - Constructor for class com.netflix.hollow.tools.diff.count.HollowDiffMissingCountingNode
-
- HollowDiffNodeIdentifier - Class in com.netflix.hollow.tools.diff
-
A breadcrumbs-like unique identifier for a field's location within a type hierarchy, used in the
HollowDiff
.
- HollowDiffNodeIdentifier(String) - Constructor for class com.netflix.hollow.tools.diff.HollowDiffNodeIdentifier
-
- HollowDiffNodeIdentifier(HollowDiffNodeIdentifier, String, String) - Constructor for class com.netflix.hollow.tools.diff.HollowDiffNodeIdentifier
-
- HollowDiffObjectCountingNode - Class in com.netflix.hollow.tools.diff.count
-
Counting nodes are used by the HollowDiff to count and aggregate changes for specific record types in a data model.
- HollowDiffObjectCountingNode(HollowDiff, HollowTypeDiff, HollowDiffNodeIdentifier, HollowObjectTypeReadState, HollowObjectTypeReadState) - Constructor for class com.netflix.hollow.tools.diff.count.HollowDiffObjectCountingNode
-
- HollowDiffRecordFieldExtractor - Class in com.netflix.hollow.tools.diff
-
- HollowDiffRecordFieldExtractor() - Constructor for class com.netflix.hollow.tools.diff.HollowDiffRecordFieldExtractor
-
- HollowDiffShortcutTypeCountingNode - Class in com.netflix.hollow.tools.diff.count
-
- HollowDiffShortcutTypeCountingNode(HollowDiff, HollowTypeDiff, HollowDiffNodeIdentifier) - Constructor for class com.netflix.hollow.tools.diff.count.HollowDiffShortcutTypeCountingNode
-
- HollowDisabledDataAccess - Class in com.netflix.hollow.core.read.dataaccess.disabled
-
A HollowDisabledDataAccess throws an IllegalStateException when access is attempted.
- HollowErgonomicAPIShortcuts - Class in com.netflix.hollow.api.codegen
-
- HollowErgonomicAPIShortcuts.Shortcut - Class in com.netflix.hollow.api.codegen
-
- HollowException - Exception in com.netflix.hollow.api.error
-
A generic exception thrown by hollow.
- HollowException(String) - Constructor for exception com.netflix.hollow.api.error.HollowException
-
- HollowException(String, Throwable) - Constructor for exception com.netflix.hollow.api.error.HollowException
-
- HollowException(Throwable) - Constructor for exception com.netflix.hollow.api.error.HollowException
-
- HollowFactory<T> - Class in com.netflix.hollow.api.objects.provider
-
A HollowFactory is responsible for returning objects in a generated Hollow Object API.
- HollowFactory() - Constructor for class com.netflix.hollow.api.objects.provider.HollowFactory
-
- hollowFactoryClassname(String) - Static method in class com.netflix.hollow.api.codegen.HollowCodeGenerationUtils
-
- HollowFactoryJavaGenerator - Class in com.netflix.hollow.api.codegen.objects
-
This class contains template logic for generating a
HollowAPI
implementation.
- HollowFactoryJavaGenerator(String, HollowSchema, HollowDataset, CodeGeneratorConfig) - Constructor for class com.netflix.hollow.api.codegen.objects.HollowFactoryJavaGenerator
-
- HollowFieldDiff - Class in com.netflix.hollow.tools.diff.count
-
Obtained via a
HollowTypeDiff
, this is a report of the differences in a specific field between two data states.
- HollowFieldDiff(HollowDiffNodeIdentifier) - Constructor for class com.netflix.hollow.tools.diff.count.HollowFieldDiff
-
- HollowFieldMatchQuery - Class in com.netflix.hollow.tools.query
-
A HollowFieldMatchQuery can be used to scan through all records in a dataset to match specific field name/value combinations.
- HollowFieldMatchQuery(HollowReadStateEngine) - Constructor for class com.netflix.hollow.tools.query.HollowFieldMatchQuery
-
- HollowFilesystemAnnouncementWatcher - Class in com.netflix.hollow.api.consumer.fs
-
- HollowFilesystemAnnouncementWatcher(Path) - Constructor for class com.netflix.hollow.api.consumer.fs.HollowFilesystemAnnouncementWatcher
-
Creates a file system announcement watcher.
- HollowFilesystemAnnouncementWatcher(Path, ScheduledExecutorService) - Constructor for class com.netflix.hollow.api.consumer.fs.HollowFilesystemAnnouncementWatcher
-
Creates a file system announcement watcher.
- HollowFilesystemAnnouncer - Class in com.netflix.hollow.api.producer.fs
-
- HollowFilesystemAnnouncer(Path) - Constructor for class com.netflix.hollow.api.producer.fs.HollowFilesystemAnnouncer
-
- HollowFilesystemBlobRetriever - Class in com.netflix.hollow.api.consumer.fs
-
- HollowFilesystemBlobRetriever(Path) - Constructor for class com.netflix.hollow.api.consumer.fs.HollowFilesystemBlobRetriever
-
A new HollowFilesystemBlobRetriever which is not backed by a remote store.
- HollowFilesystemBlobRetriever(Path, HollowConsumer.BlobRetriever) - Constructor for class com.netflix.hollow.api.consumer.fs.HollowFilesystemBlobRetriever
-
A new HollowFileSystemBlobRetriever which is backed by a remote store.
- HollowFilesystemBlobRetriever(Path, HollowConsumer.BlobRetriever, boolean) - Constructor for class com.netflix.hollow.api.consumer.fs.HollowFilesystemBlobRetriever
-
A new HollowFileSystemBlobRetriever which is backed by a remote store.
- HollowFilesystemBlobRetriever(Path, Set<String>) - Constructor for class com.netflix.hollow.api.consumer.fs.HollowFilesystemBlobRetriever
-
A new HollowFilesystemBlobRetriever which is not backed by a remote store.
- HollowFilesystemBlobStager - Class in com.netflix.hollow.api.producer.fs
-
- HollowFilesystemBlobStager() - Constructor for class com.netflix.hollow.api.producer.fs.HollowFilesystemBlobStager
-
Constructor to create a new HollowFilesystemBlobStager with default disk path
(java.io.tmpdir) and no compression for Hollow blobs.
- HollowFilesystemBlobStager(Path, HollowProducer.BlobCompressor) - Constructor for class com.netflix.hollow.api.producer.fs.HollowFilesystemBlobStager
-
Constructor to create a new HollowFilesystemBlobStager with specified disk
path and compression for Hollow blobs.
- HollowFilesystemBlobStager(Path, HollowProducer.BlobCompressor, ProducerOptionalBlobPartConfig) - Constructor for class com.netflix.hollow.api.producer.fs.HollowFilesystemBlobStager
-
- HollowFilesystemBlobStager(File, HollowProducer.BlobCompressor) - Constructor for class com.netflix.hollow.api.producer.fs.HollowFilesystemBlobStager
-
- HollowFilesystemBlobStager.FilesystemBlob - Class in com.netflix.hollow.api.producer.fs
-
- HollowFilesystemBlobStorageCleaner - Class in com.netflix.hollow.api.producer.fs
-
- HollowFilesystemBlobStorageCleaner(File) - Constructor for class com.netflix.hollow.api.producer.fs.HollowFilesystemBlobStorageCleaner
-
- HollowFilesystemBlobStorageCleaner(File, int) - Constructor for class com.netflix.hollow.api.producer.fs.HollowFilesystemBlobStorageCleaner
-
- HollowFilesystemPublisher - Class in com.netflix.hollow.api.producer.fs
-
- HollowFilesystemPublisher(Path) - Constructor for class com.netflix.hollow.api.producer.fs.HollowFilesystemPublisher
-
- HollowFilterConfig - Class in com.netflix.hollow.core.read.filter
-
- HollowFilterConfig() - Constructor for class com.netflix.hollow.core.read.filter.HollowFilterConfig
-
Deprecated.
Create a new include filter.
- HollowFilterConfig(boolean) - Constructor for class com.netflix.hollow.core.read.filter.HollowFilterConfig
-
Deprecated.
Create a new filter
- HollowFilterConfig.ObjectFilterConfig - Class in com.netflix.hollow.core.read.filter
-
Deprecated.
- HollowHashableWriteRecord - Interface in com.netflix.hollow.core.write
-
- HollowHashableWriteRecord.HashBehavior - Enum in com.netflix.hollow.core.write
-
- HollowHashIndex - Class in com.netflix.hollow.core.index
-
A HollowHashIndex is used for indexing non-primary-key data.
- HollowHashIndex(HollowReadStateEngine, String, String, String...) - Constructor for class com.netflix.hollow.core.index.HollowHashIndex
-
- HollowHashIndex.HollowHashIndexState - Class in com.netflix.hollow.core.index
-
- HollowHashIndexBuilder - Class in com.netflix.hollow.core.index
-
- HollowHashIndexBuilder(HollowReadStateEngine, String, String, String...) - Constructor for class com.netflix.hollow.core.index.HollowHashIndexBuilder
-
- HollowHashIndexField - Class in com.netflix.hollow.core.index
-
- HollowHashIndexField(int, int[], HollowTypeReadState, HollowObjectSchema.FieldType) - Constructor for class com.netflix.hollow.core.index.HollowHashIndexField
-
- HollowHashIndexGenerator - Class in com.netflix.hollow.api.codegen.indexes
-
This class contains template logic for generating a
HollowAPI
implementation.
- HollowHashIndexGenerator(String, String, HollowDataset, CodeGeneratorConfig) - Constructor for class com.netflix.hollow.api.codegen.indexes.HollowHashIndexGenerator
-
- HollowHashIndexResult - Class in com.netflix.hollow.core.index
-
A HollowHashIndexResult contains the matches for a query to a
HollowHashIndex
.
- HollowHashIndexState(HollowHashIndexBuilder) - Constructor for class com.netflix.hollow.core.index.HollowHashIndex.HollowHashIndexState
-
- HollowHashKey - Annotation Type in com.netflix.hollow.core.write.objectmapper
-
Indicates that a field, declared by a hollow object type (a POJO),
of type Set
or Map
has a hash key defining how the
hollow objects that are elements in a Set
or are keys in a
Map
are hashed.
- HollowHistoricalListDataAccess - Class in com.netflix.hollow.tools.history
-
- HollowHistoricalListDataAccess(HollowHistoricalStateDataAccess, HollowTypeReadState) - Constructor for class com.netflix.hollow.tools.history.HollowHistoricalListDataAccess
-
- HollowHistoricalMapDataAccess - Class in com.netflix.hollow.tools.history
-
- HollowHistoricalMapDataAccess(HollowHistoricalStateDataAccess, HollowTypeReadState) - Constructor for class com.netflix.hollow.tools.history.HollowHistoricalMapDataAccess
-
- HollowHistoricalObjectDataAccess - Class in com.netflix.hollow.tools.history
-
- HollowHistoricalObjectDataAccess(HollowHistoricalStateDataAccess, HollowTypeReadState) - Constructor for class com.netflix.hollow.tools.history.HollowHistoricalObjectDataAccess
-
- HollowHistoricalSchemaChange - Class in com.netflix.hollow.tools.history
-
- HollowHistoricalSchemaChange(HollowSchema, HollowSchema) - Constructor for class com.netflix.hollow.tools.history.HollowHistoricalSchemaChange
-
- HollowHistoricalSetDataAccess - Class in com.netflix.hollow.tools.history
-
- HollowHistoricalSetDataAccess(HollowHistoricalStateDataAccess, HollowTypeReadState) - Constructor for class com.netflix.hollow.tools.history.HollowHistoricalSetDataAccess
-
- HollowHistoricalState - Class in com.netflix.hollow.tools.history
-
A data state from the past, represented as just the changes which happened on the subsequent transition.
- HollowHistoricalState(long, HollowHistoricalStateKeyOrdinalMapping, HollowHistoricalStateDataAccess, Map<String, String>) - Constructor for class com.netflix.hollow.tools.history.HollowHistoricalState
-
- HollowHistoricalStateCreator - Class in com.netflix.hollow.tools.history
-
- HollowHistoricalStateCreator() - Constructor for class com.netflix.hollow.tools.history.HollowHistoricalStateCreator
-
- HollowHistoricalStateCreator(HollowHistory) - Constructor for class com.netflix.hollow.tools.history.HollowHistoricalStateCreator
-
- HollowHistoricalStateDataAccess - Class in com.netflix.hollow.tools.history
-
- HollowHistoricalStateDataAccess(HollowHistory, long, HollowReadStateEngine, OrdinalRemapper, Map<String, HollowHistoricalSchemaChange>) - Constructor for class com.netflix.hollow.tools.history.HollowHistoricalStateDataAccess
-
- HollowHistoricalStateDataAccess(HollowHistory, long, HollowReadStateEngine, Collection<HollowTypeReadState>, OrdinalRemapper, Map<String, HollowHistoricalSchemaChange>) - Constructor for class com.netflix.hollow.tools.history.HollowHistoricalStateDataAccess
-
- HollowHistoricalStateKeyOrdinalMapping - Class in com.netflix.hollow.tools.history.keyindex
-
- HollowHistoricalStateKeyOrdinalMapping(HollowHistoryKeyIndex) - Constructor for class com.netflix.hollow.tools.history.keyindex.HollowHistoricalStateKeyOrdinalMapping
-
- HollowHistoricalStateTypeKeyOrdinalMapping - Class in com.netflix.hollow.tools.history.keyindex
-
- HollowHistoricalStateTypeKeyOrdinalMapping(String, HollowHistoryTypeKeyIndex) - Constructor for class com.netflix.hollow.tools.history.keyindex.HollowHistoricalStateTypeKeyOrdinalMapping
-
- HollowHistoricalTypeDataAccess - Class in com.netflix.hollow.tools.history
-
- HollowHistoricalTypeDataAccess(HollowHistoricalStateDataAccess, HollowTypeReadState, HollowSampler) - Constructor for class com.netflix.hollow.tools.history.HollowHistoricalTypeDataAccess
-
- HollowHistory - Class in com.netflix.hollow.tools.history
-
Retains, in memory, the changes in a dataset over many states.
- HollowHistory(HollowReadStateEngine, long, int) - Constructor for class com.netflix.hollow.tools.history.HollowHistory
-
- HollowHistory(HollowReadStateEngine, long, int, boolean) - Constructor for class com.netflix.hollow.tools.history.HollowHistory
-
- HollowHistoryKeyIndex - Class in com.netflix.hollow.tools.history.keyindex
-
- HollowHistoryKeyIndex(HollowHistory) - Constructor for class com.netflix.hollow.tools.history.keyindex.HollowHistoryKeyIndex
-
- HollowHistoryTypeKeyIndex - Class in com.netflix.hollow.tools.history.keyindex
-
- HollowHistoryTypeKeyIndex(PrimaryKey, HollowDataset, HollowWriteStateEngine, HollowReadStateEngine) - Constructor for class com.netflix.hollow.tools.history.keyindex.HollowHistoryTypeKeyIndex
-
- hollowImplClassname(String, String, boolean, boolean) - Static method in class com.netflix.hollow.api.codegen.HollowCodeGenerationUtils
-
- hollowImplClassname(String) - Method in class com.netflix.hollow.api.codegen.HollowConsumerJavaFileGenerator
-
- HollowIncrementalCyclePopulator - Class in com.netflix.hollow.api.producer
-
- HollowIncrementalProducer - Class in com.netflix.hollow.api.producer
-
- HollowIncrementalProducer(HollowProducer) - Constructor for class com.netflix.hollow.api.producer.HollowIncrementalProducer
-
Deprecated.
- HollowIncrementalProducer(HollowProducer, double) - Constructor for class com.netflix.hollow.api.producer.HollowIncrementalProducer
-
Deprecated.
- HollowIncrementalProducer(HollowProducer, double, HollowConsumer.AnnouncementWatcher, HollowConsumer.BlobRetriever, List<IncrementalCycleListener>, Class<?>...) - Constructor for class com.netflix.hollow.api.producer.HollowIncrementalProducer
-
Deprecated.
- HollowIncrementalProducer.Builder<B extends HollowIncrementalProducer.Builder<B>> - Class in com.netflix.hollow.api.producer
-
Deprecated.
- HollowIndexerValueTraverser - Class in com.netflix.hollow.core.index.traversal
-
Used by the HollowHashIndex to traverse the possible value combinations of individual records given
a set of field paths.
- HollowIndexerValueTraverser(HollowDataAccess, String, String...) - Constructor for class com.netflix.hollow.core.index.traversal.HollowIndexerValueTraverser
-
- HollowIndexGenerator - Class in com.netflix.hollow.api.codegen.indexes
-
- HollowIndexGenerator(String, String, HollowDataset, CodeGeneratorConfig) - Constructor for class com.netflix.hollow.api.codegen.indexes.HollowIndexGenerator
-
- HollowInline - Annotation Type in com.netflix.hollow.core.write.objectmapper
-
Indicates that a field of a POJO is inlined as a value rather than
a reference.
- HollowInMemoryBlobStager - Class in com.netflix.hollow.api.producer.fs
-
- HollowInMemoryBlobStager() - Constructor for class com.netflix.hollow.api.producer.fs.HollowInMemoryBlobStager
-
- HollowInMemoryBlobStager(ProducerOptionalBlobPartConfig) - Constructor for class com.netflix.hollow.api.producer.fs.HollowInMemoryBlobStager
-
- HollowInMemoryBlobStager.InMemoryBlob - Class in com.netflix.hollow.api.producer.fs
-
- HollowJavaFileGenerator - Interface in com.netflix.hollow.api.codegen
-
Not intended for external consumption.
- HollowList<T> - Class in com.netflix.hollow.api.objects
-
A HollowList provides an implementation of the List
interface over
a LIST record in a Hollow dataset.
- HollowList(HollowListDelegate<T>, int) - Constructor for class com.netflix.hollow.api.objects.HollowList
-
- HollowListCachedDelegate<T> - Class in com.netflix.hollow.api.objects.delegate
-
- HollowListCachedDelegate(HollowListTypeDataAccess, int) - Constructor for class com.netflix.hollow.api.objects.delegate.HollowListCachedDelegate
-
- HollowListCachedDelegate(HollowListTypeAPI, int) - Constructor for class com.netflix.hollow.api.objects.delegate.HollowListCachedDelegate
-
- HollowListCopier - Class in com.netflix.hollow.core.write.copy
-
- HollowListCopier(HollowListTypeReadState, OrdinalRemapper) - Constructor for class com.netflix.hollow.core.write.copy.HollowListCopier
-
- HollowListDelegate<T> - Interface in com.netflix.hollow.api.objects.delegate
-
- HollowListDeltaHistoricalStateCreator - Class in com.netflix.hollow.core.read.engine.list
-
This class contains the logic for extracting the removed records from a LIST type state
to produce a historical type state.
- HollowListDeltaHistoricalStateCreator(HollowListTypeReadState) - Constructor for class com.netflix.hollow.core.read.engine.list.HollowListDeltaHistoricalStateCreator
-
- HollowListDisabledDataAccess - Class in com.netflix.hollow.core.read.dataaccess.disabled
-
- HollowListJavaGenerator - Class in com.netflix.hollow.api.codegen.objects
-
This class contains template logic for generating a
HollowAPI
implementation.
- HollowListJavaGenerator(String, String, HollowListSchema, Set<String>, boolean, HollowDataset, CodeGeneratorConfig) - Constructor for class com.netflix.hollow.api.codegen.objects.HollowListJavaGenerator
-
- HollowListLookupDelegate<T> - Class in com.netflix.hollow.api.objects.delegate
-
- HollowListLookupDelegate(HollowListTypeDataAccess) - Constructor for class com.netflix.hollow.api.objects.delegate.HollowListLookupDelegate
-
- HollowListLookupDelegate(HollowListTypeAPI) - Constructor for class com.netflix.hollow.api.objects.delegate.HollowListLookupDelegate
-
- HollowListMissingDataAccess - Class in com.netflix.hollow.core.read.dataaccess.missing
-
Used when an entire LIST type, which is expected by a Generated Hollow API, is missing from the actual data.
- HollowListMissingDataAccess(HollowDataAccess, String) - Constructor for class com.netflix.hollow.core.read.dataaccess.missing.HollowListMissingDataAccess
-
- HollowListOrdinalIterator - Class in com.netflix.hollow.core.read.iterator
-
- HollowListOrdinalIterator(int, HollowListTypeDataAccess) - Constructor for class com.netflix.hollow.core.read.iterator.HollowListOrdinalIterator
-
- HollowListProxyDataAccess - Class in com.netflix.hollow.core.read.dataaccess.proxy
-
- HollowListProxyDataAccess(HollowProxyDataAccess) - Constructor for class com.netflix.hollow.core.read.dataaccess.proxy.HollowListProxyDataAccess
-
- HollowListSampler - Class in com.netflix.hollow.api.sampling
-
- HollowListSampler(String, HollowSamplingDirector) - Constructor for class com.netflix.hollow.api.sampling.HollowListSampler
-
- HollowListSchema - Class in com.netflix.hollow.core.schema
-
A schema for a List record type.
- HollowListSchema(String, String) - Constructor for class com.netflix.hollow.core.schema.HollowListSchema
-
- HollowListTypeAPI - Class in com.netflix.hollow.api.custom
-
This is the Hollow Type API interface for LIST type records.
- HollowListTypeAPI(HollowAPI, HollowListTypeDataAccess) - Constructor for class com.netflix.hollow.api.custom.HollowListTypeAPI
-
- HollowListTypeDataAccess - Interface in com.netflix.hollow.core.read.dataaccess
-
A handle for all of the records of a specific LIST type in a Hollow dataset.
- HollowListTypeDataElements - Class in com.netflix.hollow.core.read.engine.list
-
- HollowListTypeDataElements(ArraySegmentRecycler) - Constructor for class com.netflix.hollow.core.read.engine.list.HollowListTypeDataElements
-
- HollowListTypeDataElements(MemoryMode, ArraySegmentRecycler) - Constructor for class com.netflix.hollow.core.read.engine.list.HollowListTypeDataElements
-
- HollowListTypeMapper - Class in com.netflix.hollow.core.write.objectmapper
-
- HollowListTypeMapper(HollowObjectMapper, ParameterizedType, String, int, boolean, Set<Type>) - Constructor for class com.netflix.hollow.core.write.objectmapper.HollowListTypeMapper
-
- HollowListTypeReadState - Class in com.netflix.hollow.core.read.engine.list
-
- HollowListTypeReadState(HollowReadStateEngine, HollowListSchema, int) - Constructor for class com.netflix.hollow.core.read.engine.list.HollowListTypeReadState
-
- HollowListTypeReadState(HollowReadStateEngine, MemoryMode, HollowListSchema, int) - Constructor for class com.netflix.hollow.core.read.engine.list.HollowListTypeReadState
-
- HollowListTypeWriteState - Class in com.netflix.hollow.core.write
-
- HollowListTypeWriteState(HollowListSchema) - Constructor for class com.netflix.hollow.core.write.HollowListTypeWriteState
-
- HollowListTypeWriteState(HollowListSchema, int) - Constructor for class com.netflix.hollow.core.write.HollowListTypeWriteState
-
- HollowListWriteRecord - Class in com.netflix.hollow.core.write
-
- HollowListWriteRecord() - Constructor for class com.netflix.hollow.core.write.HollowListWriteRecord
-
- HollowMap<K,V> - Class in com.netflix.hollow.api.objects
-
A HollowMap provides an implementation of the Map
interface over
a MAP record in a Hollow dataset.
- HollowMap(HollowMapDelegate<K, V>, int) - Constructor for class com.netflix.hollow.api.objects.HollowMap
-
- HollowMapCachedDelegate<K,V> - Class in com.netflix.hollow.api.objects.delegate
-
- HollowMapCachedDelegate(HollowMapTypeDataAccess, int) - Constructor for class com.netflix.hollow.api.objects.delegate.HollowMapCachedDelegate
-
- HollowMapCachedDelegate(HollowMapTypeAPI, int) - Constructor for class com.netflix.hollow.api.objects.delegate.HollowMapCachedDelegate
-
- HollowMapCopier - Class in com.netflix.hollow.core.write.copy
-
- HollowMapCopier(HollowMapTypeReadState, OrdinalRemapper, boolean) - Constructor for class com.netflix.hollow.core.write.copy.HollowMapCopier
-
- HollowMapDelegate<K,V> - Interface in com.netflix.hollow.api.objects.delegate
-
- HollowMapDeltaHistoricalStateCreator - Class in com.netflix.hollow.core.read.engine.map
-
This class contains the logic for extracting the removed records from a MAP type state
to produce a historical type state.
- HollowMapDeltaHistoricalStateCreator(HollowMapTypeReadState) - Constructor for class com.netflix.hollow.core.read.engine.map.HollowMapDeltaHistoricalStateCreator
-
- HollowMapDisabledDataAccess - Class in com.netflix.hollow.core.read.dataaccess.disabled
-
- HollowMapEntryOrdinalIterator - Interface in com.netflix.hollow.core.read.iterator
-
- HollowMapEntryOrdinalIteratorImpl - Class in com.netflix.hollow.core.read.iterator
-
- HollowMapEntryOrdinalIteratorImpl(int, HollowMapTypeDataAccess) - Constructor for class com.netflix.hollow.core.read.iterator.HollowMapEntryOrdinalIteratorImpl
-
- HollowMapJavaGenerator - Class in com.netflix.hollow.api.codegen.objects
-
This class contains template logic for generating a
HollowAPI
implementation.
- HollowMapJavaGenerator(String, String, HollowMapSchema, HollowDataset, Set<String>, boolean, CodeGeneratorConfig) - Constructor for class com.netflix.hollow.api.codegen.objects.HollowMapJavaGenerator
-
- HollowMapLookupDelegate<K,V> - Class in com.netflix.hollow.api.objects.delegate
-
- HollowMapLookupDelegate(HollowMapTypeDataAccess) - Constructor for class com.netflix.hollow.api.objects.delegate.HollowMapLookupDelegate
-
- HollowMapLookupDelegate(HollowMapTypeAPI) - Constructor for class com.netflix.hollow.api.objects.delegate.HollowMapLookupDelegate
-
- HollowMapMissingDataAccess - Class in com.netflix.hollow.core.read.dataaccess.missing
-
Used when an entire MAP type, which is expected by a Generated Hollow API, is missing from the actual data.
- HollowMapMissingDataAccess(HollowDataAccess, String) - Constructor for class com.netflix.hollow.core.read.dataaccess.missing.HollowMapMissingDataAccess
-
- HollowMapProxyDataAccess - Class in com.netflix.hollow.core.read.dataaccess.proxy
-
- HollowMapProxyDataAccess(HollowProxyDataAccess) - Constructor for class com.netflix.hollow.core.read.dataaccess.proxy.HollowMapProxyDataAccess
-
- HollowMapSampler - Class in com.netflix.hollow.api.sampling
-
- HollowMapSampler(String, HollowSamplingDirector) - Constructor for class com.netflix.hollow.api.sampling.HollowMapSampler
-
- HollowMapSchema - Class in com.netflix.hollow.core.schema
-
A schema for a Map record type
- HollowMapSchema(String, String, String, String...) - Constructor for class com.netflix.hollow.core.schema.HollowMapSchema
-
- HollowMapTypeAPI - Class in com.netflix.hollow.api.custom
-
This is the Hollow Type API interface for MAP type records.
- HollowMapTypeAPI(HollowAPI, HollowMapTypeDataAccess) - Constructor for class com.netflix.hollow.api.custom.HollowMapTypeAPI
-
- HollowMapTypeDataAccess - Interface in com.netflix.hollow.core.read.dataaccess
-
A handle for all of the records of a specific MAP type in a Hollow dataset.
- HollowMapTypeDataElements - Class in com.netflix.hollow.core.read.engine.map
-
- HollowMapTypeDataElements(ArraySegmentRecycler) - Constructor for class com.netflix.hollow.core.read.engine.map.HollowMapTypeDataElements
-
- HollowMapTypeDataElements(MemoryMode, ArraySegmentRecycler) - Constructor for class com.netflix.hollow.core.read.engine.map.HollowMapTypeDataElements
-
- HollowMapTypeMapper - Class in com.netflix.hollow.core.write.objectmapper
-
- HollowMapTypeMapper(HollowObjectMapper, ParameterizedType, String, String[], int, HollowWriteStateEngine, boolean, Set<Type>) - Constructor for class com.netflix.hollow.core.write.objectmapper.HollowMapTypeMapper
-
- HollowMapTypeReadState - Class in com.netflix.hollow.core.read.engine.map
-
- HollowMapTypeReadState(HollowReadStateEngine, HollowMapSchema, int) - Constructor for class com.netflix.hollow.core.read.engine.map.HollowMapTypeReadState
-
- HollowMapTypeReadState(HollowReadStateEngine, MemoryMode, HollowMapSchema, int) - Constructor for class com.netflix.hollow.core.read.engine.map.HollowMapTypeReadState
-
- HollowMapTypeWriteState - Class in com.netflix.hollow.core.write
-
- HollowMapTypeWriteState(HollowMapSchema) - Constructor for class com.netflix.hollow.core.write.HollowMapTypeWriteState
-
- HollowMapTypeWriteState(HollowMapSchema, int) - Constructor for class com.netflix.hollow.core.write.HollowMapTypeWriteState
-
- HollowMapWriteRecord - Class in com.netflix.hollow.core.write
-
- HollowMapWriteRecord() - Constructor for class com.netflix.hollow.core.write.HollowMapWriteRecord
-
- HollowMapWriteRecord(HollowHashableWriteRecord.HashBehavior) - Constructor for class com.netflix.hollow.core.write.HollowMapWriteRecord
-
- HollowMetrics - Class in com.netflix.hollow.api.metrics
-
- HollowMetrics() - Constructor for class com.netflix.hollow.api.metrics.HollowMetrics
-
- HollowMetricsCollector<T extends HollowMetrics> - Class in com.netflix.hollow.api.metrics
-
- HollowMetricsCollector() - Constructor for class com.netflix.hollow.api.metrics.HollowMetricsCollector
-
- HollowObject - Class in com.netflix.hollow.api.objects
-
A HollowObject provides an interface for accessing data from an OBJECT record in
a hollow dataset.
- HollowObject(HollowObjectDelegate, int) - Constructor for class com.netflix.hollow.api.objects.HollowObject
-
- HollowObjectAbstractDelegate - Class in com.netflix.hollow.api.objects.delegate
-
Contains some basic convenience access methods for OBJECT record fields.
- HollowObjectAbstractDelegate() - Constructor for class com.netflix.hollow.api.objects.delegate.HollowObjectAbstractDelegate
-
- HollowObjectCacheProvider<T> - Class in com.netflix.hollow.api.objects.provider
-
A HollowObjectCacheProvider caches and returns Object representations (presumably
HollowRecord
s) of
records of a specific type.
- HollowObjectCacheProvider(HollowTypeDataAccess, HollowTypeAPI, HollowFactory<T>) - Constructor for class com.netflix.hollow.api.objects.provider.HollowObjectCacheProvider
-
- HollowObjectCacheProvider(HollowTypeDataAccess, HollowTypeAPI, HollowFactory<T>, HollowObjectCacheProvider<T>) - Constructor for class com.netflix.hollow.api.objects.provider.HollowObjectCacheProvider
-
- HollowObjectCopier - Class in com.netflix.hollow.core.write.copy
-
- HollowObjectCopier(HollowObjectTypeReadState, HollowObjectSchema, OrdinalRemapper) - Constructor for class com.netflix.hollow.core.write.copy.HollowObjectCopier
-
- HollowObjectCreationSampler - Class in com.netflix.hollow.api.sampling
-
- HollowObjectCreationSampler(String...) - Constructor for class com.netflix.hollow.api.sampling.HollowObjectCreationSampler
-
- HollowObjectDelegate - Interface in com.netflix.hollow.api.objects.delegate
-
- HollowObjectDelegateCachedImplGenerator - Class in com.netflix.hollow.api.codegen.delegate
-
This class contains template logic for generating a
HollowAPI
implementation.
- HollowObjectDelegateCachedImplGenerator(String, HollowObjectSchema, HollowErgonomicAPIShortcuts, HollowDataset, CodeGeneratorConfig) - Constructor for class com.netflix.hollow.api.codegen.delegate.HollowObjectDelegateCachedImplGenerator
-
- HollowObjectDelegateGenerator - Class in com.netflix.hollow.api.codegen.delegate
-
- HollowObjectDelegateGenerator(String, HollowObjectSchema, HollowErgonomicAPIShortcuts, HollowDataset, CodeGeneratorConfig) - Constructor for class com.netflix.hollow.api.codegen.delegate.HollowObjectDelegateGenerator
-
- HollowObjectDelegateInterfaceGenerator - Class in com.netflix.hollow.api.codegen.delegate
-
This class contains template logic for generating a
HollowAPI
implementation.
- HollowObjectDelegateInterfaceGenerator(String, HollowObjectSchema, HollowErgonomicAPIShortcuts, HollowDataset, CodeGeneratorConfig) - Constructor for class com.netflix.hollow.api.codegen.delegate.HollowObjectDelegateInterfaceGenerator
-
- HollowObjectDelegateLookupImplGenerator - Class in com.netflix.hollow.api.codegen.delegate
-
This class contains template logic for generating a
HollowAPI
implementation.
- HollowObjectDelegateLookupImplGenerator(String, HollowObjectSchema, HollowErgonomicAPIShortcuts, HollowDataset, CodeGeneratorConfig) - Constructor for class com.netflix.hollow.api.codegen.delegate.HollowObjectDelegateLookupImplGenerator
-
- HollowObjectDeltaHistoricalStateCreator - Class in com.netflix.hollow.core.read.engine.object
-
This class contains the logic for extracting the removed records from an OBJECT type state
to produce a historical type state.
- HollowObjectDeltaHistoricalStateCreator(HollowObjectTypeReadState) - Constructor for class com.netflix.hollow.core.read.engine.object.HollowObjectDeltaHistoricalStateCreator
-
- HollowObjectDisabledDataAccess - Class in com.netflix.hollow.core.read.dataaccess.disabled
-
- HollowObjectFactoryProvider<T> - Class in com.netflix.hollow.api.objects.provider
-
A HollowObjectFactoryProvider recreates Hollow objects each time they are called for.
- HollowObjectFactoryProvider(HollowTypeDataAccess, HollowTypeAPI, HollowFactory<T>) - Constructor for class com.netflix.hollow.api.objects.provider.HollowObjectFactoryProvider
-
- HollowObjectGenericDelegate - Class in com.netflix.hollow.api.objects.delegate
-
- HollowObjectGenericDelegate(HollowObjectTypeDataAccess) - Constructor for class com.netflix.hollow.api.objects.delegate.HollowObjectGenericDelegate
-
- HollowObjectHashCodeFinder - Interface in com.netflix.hollow.core.util
-
- HollowObjectJavaGenerator - Class in com.netflix.hollow.api.codegen.objects
-
This class contains template logic for generating a
HollowAPI
implementation.
- HollowObjectJavaGenerator(String, String, HollowObjectSchema, Set<String>, boolean, HollowErgonomicAPIShortcuts, HollowDataset, CodeGeneratorConfig) - Constructor for class com.netflix.hollow.api.codegen.objects.HollowObjectJavaGenerator
-
- HollowObjectMapper - Class in com.netflix.hollow.core.write.objectmapper
-
- HollowObjectMapper(HollowWriteStateEngine) - Constructor for class com.netflix.hollow.core.write.objectmapper.HollowObjectMapper
-
- HollowObjectMissingDataAccess - Class in com.netflix.hollow.core.read.dataaccess.missing
-
Used when an entire OBJECT type, which is expected by a Generated Hollow API, is missing from the actual data.
- HollowObjectMissingDataAccess(HollowDataAccess, String) - Constructor for class com.netflix.hollow.core.read.dataaccess.missing.HollowObjectMissingDataAccess
-
- HollowObjectProvider<T> - Class in com.netflix.hollow.api.objects.provider
-
- HollowObjectProvider() - Constructor for class com.netflix.hollow.api.objects.provider.HollowObjectProvider
-
- hollowObjectProviderName(String) - Static method in class com.netflix.hollow.api.codegen.HollowCodeGenerationUtils
-
- HollowObjectProxyDataAccess - Class in com.netflix.hollow.core.read.dataaccess.proxy
-
- HollowObjectProxyDataAccess(HollowProxyDataAccess) - Constructor for class com.netflix.hollow.core.read.dataaccess.proxy.HollowObjectProxyDataAccess
-
- HollowObjectSampler - Class in com.netflix.hollow.api.sampling
-
- HollowObjectSampler(HollowObjectSchema, HollowSamplingDirector) - Constructor for class com.netflix.hollow.api.sampling.HollowObjectSampler
-
- HollowObjectSchema - Class in com.netflix.hollow.core.schema
-
A schema for an Object record type.
- HollowObjectSchema(String, int, String...) - Constructor for class com.netflix.hollow.core.schema.HollowObjectSchema
-
- HollowObjectSchema(String, int, PrimaryKey) - Constructor for class com.netflix.hollow.core.schema.HollowObjectSchema
-
- HollowObjectSchema.FieldType - Enum in com.netflix.hollow.core.schema
-
All allowable field types.
- HollowObjectTypeAPI - Class in com.netflix.hollow.api.custom
-
This is the Hollow Type API interface for OBJECT type records.
- HollowObjectTypeAPI(HollowAPI, HollowObjectTypeDataAccess, String[]) - Constructor for class com.netflix.hollow.api.custom.HollowObjectTypeAPI
-
- HollowObjectTypeDataAccess - Interface in com.netflix.hollow.core.read.dataaccess
-
A handle for all of the records of a specific OBJECT type in a Hollow dataset.
- HollowObjectTypeDataElements - Class in com.netflix.hollow.core.read.engine.object
-
- HollowObjectTypeDataElements(HollowObjectSchema, ArraySegmentRecycler) - Constructor for class com.netflix.hollow.core.read.engine.object.HollowObjectTypeDataElements
-
- HollowObjectTypeDataElements(HollowObjectSchema, MemoryMode, ArraySegmentRecycler) - Constructor for class com.netflix.hollow.core.read.engine.object.HollowObjectTypeDataElements
-
- HollowObjectTypeMapper - Class in com.netflix.hollow.core.write.objectmapper
-
- HollowObjectTypeMapper(HollowObjectMapper, Class<?>, String, Set<Type>) - Constructor for class com.netflix.hollow.core.write.objectmapper.HollowObjectTypeMapper
-
- HollowObjectTypeReadState - Class in com.netflix.hollow.core.read.engine.object
-
- HollowObjectTypeReadState(HollowReadStateEngine, HollowObjectSchema) - Constructor for class com.netflix.hollow.core.read.engine.object.HollowObjectTypeReadState
-
- HollowObjectTypeReadState(HollowReadStateEngine, MemoryMode, HollowObjectSchema, HollowObjectSchema, int) - Constructor for class com.netflix.hollow.core.read.engine.object.HollowObjectTypeReadState
-
- HollowObjectTypeWriteState - Class in com.netflix.hollow.core.write
-
- HollowObjectTypeWriteState(HollowObjectSchema) - Constructor for class com.netflix.hollow.core.write.HollowObjectTypeWriteState
-
- HollowObjectTypeWriteState(HollowObjectSchema, int) - Constructor for class com.netflix.hollow.core.write.HollowObjectTypeWriteState
-
- HollowObjectWriteRecord - Class in com.netflix.hollow.core.write
-
- HollowObjectWriteRecord(HollowObjectSchema) - Constructor for class com.netflix.hollow.core.write.HollowObjectWriteRecord
-
- HollowOrdinalIterator - Interface in com.netflix.hollow.core.read.iterator
-
An iterator over ordinals.
- HollowPatcherCombinerCopyDirector - Class in com.netflix.hollow.tools.patch.record
-
- HollowPatcherCombinerCopyDirector(HollowReadStateEngine, Map<String, BitSet>, HollowReadStateEngine, Map<String, BitSet>) - Constructor for class com.netflix.hollow.tools.patch.record.HollowPatcherCombinerCopyDirector
-
- HollowPOJOClassGenerator - Class in com.netflix.hollow.api.codegen
-
This class contains template logic for generating POJOs.
- HollowPOJOClassGenerator(HollowDataset, HollowObjectSchema, String, String) - Constructor for class com.netflix.hollow.api.codegen.HollowPOJOClassGenerator
-
- HollowPOJOClassGenerator(HollowDataset, HollowObjectSchema, String, String, boolean) - Constructor for class com.netflix.hollow.api.codegen.HollowPOJOClassGenerator
-
- HollowPOJOGenerator - Class in com.netflix.hollow.api.codegen
-
- HollowPOJOGenerator(String, String, HollowDataset) - Constructor for class com.netflix.hollow.api.codegen.HollowPOJOGenerator
-
- HollowPOJOGenerator.GeneratorArguments - Enum in com.netflix.hollow.api.codegen
-
An enumeration of possible arguments to the code generator when being called via the main
function.
- HollowPrefixIndex - Class in com.netflix.hollow.core.index
-
This class builds a prefix index.
- HollowPrefixIndex(HollowReadStateEngine, String, String) - Constructor for class com.netflix.hollow.core.index.HollowPrefixIndex
-
This constructor defaults the estimatedMaxStringDuplicates to 4.
- HollowPrefixIndex(HollowReadStateEngine, String, String, int) - Constructor for class com.netflix.hollow.core.index.HollowPrefixIndex
-
Initializes a new prefix index.
- HollowPreindexer - Class in com.netflix.hollow.core.index
-
- HollowPreindexer(HollowReadStateEngine, String, String, String...) - Constructor for class com.netflix.hollow.core.index.HollowPreindexer
-
- HollowPrimaryKey - Annotation Type in com.netflix.hollow.core.write.objectmapper
-
Indicates that a hollow object type (a POJO) has a primary key.
- HollowPrimaryKeyIndex - Class in com.netflix.hollow.core.index
-
A HollowPrimaryKeyIndex is the go-to mechanism for indexing and querying data in a Hollow blob.
- HollowPrimaryKeyIndex(HollowReadStateEngine, String, String...) - Constructor for class com.netflix.hollow.core.index.HollowPrimaryKeyIndex
-
- HollowPrimaryKeyIndex(HollowReadStateEngine, PrimaryKey) - Constructor for class com.netflix.hollow.core.index.HollowPrimaryKeyIndex
-
- HollowPrimaryKeyIndex(HollowReadStateEngine, ArraySegmentRecycler, String, String...) - Constructor for class com.netflix.hollow.core.index.HollowPrimaryKeyIndex
-
- HollowPrimaryKeyIndex(HollowReadStateEngine, PrimaryKey, ArraySegmentRecycler) - Constructor for class com.netflix.hollow.core.index.HollowPrimaryKeyIndex
-
- HollowPrimaryKeyIndex(HollowReadStateEngine, PrimaryKey, ArraySegmentRecycler, BitSet) - Constructor for class com.netflix.hollow.core.index.HollowPrimaryKeyIndex
-
This initializer can be used to create a HollowPrimaryKeyIndex which will only index a subset of the records in the specified type.
- HollowPrimaryKeyIndexGenerator - Class in com.netflix.hollow.api.codegen.indexes
-
This class contains template logic for generating a
HollowAPI
implementation.
- HollowPrimaryKeyIndexGenerator(HollowDataset, String, String, HollowObjectSchema, CodeGeneratorConfig) - Constructor for class com.netflix.hollow.api.codegen.indexes.HollowPrimaryKeyIndexGenerator
-
- HollowPrimaryKeyValueDeriver - Class in com.netflix.hollow.core.index.key
-
Used to retrieve and test equality of PrimaryKey values for records.
- HollowPrimaryKeyValueDeriver(PrimaryKey, HollowReadStateEngine) - Constructor for class com.netflix.hollow.core.index.key.HollowPrimaryKeyValueDeriver
-
Create a new deriver.
- HollowPrimaryKeyValueDeriver(HollowObjectTypeReadState, int[][], HollowObjectSchema.FieldType[]) - Constructor for class com.netflix.hollow.core.index.key.HollowPrimaryKeyValueDeriver
-
- HollowProducer - Class in com.netflix.hollow.api.producer
-
A HollowProducer is the top-level class used by producers of Hollow data to populate, publish, and announce data states.
- HollowProducer(HollowProducer.Publisher, HollowProducer.Announcer) - Constructor for class com.netflix.hollow.api.producer.HollowProducer
-
Deprecated.
- HollowProducer(HollowProducer.Builder<?>) - Constructor for class com.netflix.hollow.api.producer.HollowProducer
-
- HollowProducer.Announcer - Interface in com.netflix.hollow.api.producer
-
- HollowProducer.Blob - Class in com.netflix.hollow.api.producer
-
- HollowProducer.Blob.Type - Enum in com.netflix.hollow.api.producer
-
Hollow blob types are SNAPSHOT
, DELTA
and REVERSE_DELTA
.
- HollowProducer.BlobCompressor - Interface in com.netflix.hollow.api.producer
-
- HollowProducer.BlobStager - Interface in com.netflix.hollow.api.producer
-
- HollowProducer.BlobStorageCleaner - Class in com.netflix.hollow.api.producer
-
Provides the opportunity to clean the blob storage.
- HollowProducer.Builder<B extends HollowProducer.Builder<B>> - Class in com.netflix.hollow.api.producer
-
- HollowProducer.ChecksumValidationException - Exception in com.netflix.hollow.api.producer
-
- HollowProducer.Incremental - Class in com.netflix.hollow.api.producer
-
A producer of Hollow data that populates with given data changes (addition, modification or removal), termed
incremental production.
- HollowProducer.Incremental.IncrementalPopulator - Interface in com.netflix.hollow.api.producer
-
Represents a task that incrementally populates a new data state within a
HollowProducer
cycle (
more specifically within the population stage)
- HollowProducer.Incremental.IncrementalWriteState - Interface in com.netflix.hollow.api.producer
-
Representation of write state that can be incrementally changed.
- HollowProducer.Populator - Interface in com.netflix.hollow.api.producer
-
Represents a task that populates a new data state within a
HollowProducer
cycle.
- HollowProducer.Publisher - Interface in com.netflix.hollow.api.producer
-
- HollowProducer.ReadState - Interface in com.netflix.hollow.api.producer
-
Representation of read state computed from the population of new write state.
- HollowProducer.VersionMinter - Interface in com.netflix.hollow.api.producer
-
- HollowProducer.WriteState - Interface in com.netflix.hollow.api.producer
-
Representation of new write state.
- HollowProducerEventListener - Interface in com.netflix.hollow.api.producer.listener
-
The top-level type for all producer-specific listeners.
- HollowProducerListener - Interface in com.netflix.hollow.api.producer
-
A class should implement
HollowProducerListener
, if it wants to be notified on
start/completion of various stages of the
HollowProducer
.
- HollowProducerListener.ProducerStatus - Class in com.netflix.hollow.api.producer
-
This class represents information on details when
HollowProducer
has finished executing a particular stage.
- HollowProducerListener.PublishStatus - Class in com.netflix.hollow.api.producer
-
- HollowProducerListener.RestoreStatus - Class in com.netflix.hollow.api.producer
-
This class represents information on details when
HollowProducer
has finished executing a particular stage.
- HollowProducerListener.Status - Enum in com.netflix.hollow.api.producer
-
- HollowProducerMetrics - Class in com.netflix.hollow.api.metrics
-
- HollowProducerMetrics() - Constructor for class com.netflix.hollow.api.metrics.HollowProducerMetrics
-
- HollowProxyDataAccess - Class in com.netflix.hollow.core.read.dataaccess.proxy
-
- HollowProxyDataAccess() - Constructor for class com.netflix.hollow.core.read.dataaccess.proxy.HollowProxyDataAccess
-
- HollowReadFieldUtils - Class in com.netflix.hollow.core.read
-
- HollowReadFieldUtils() - Constructor for class com.netflix.hollow.core.read.HollowReadFieldUtils
-
- HollowReadStateEngine - Class in com.netflix.hollow.core.read.engine
-
A HollowReadStateEngine is our main handle to the current state of a Hollow dataset as a data consumer.
- HollowReadStateEngine() - Constructor for class com.netflix.hollow.core.read.engine.HollowReadStateEngine
-
- HollowReadStateEngine(boolean) - Constructor for class com.netflix.hollow.core.read.engine.HollowReadStateEngine
-
- HollowReadStateEngine(ArraySegmentRecycler) - Constructor for class com.netflix.hollow.core.read.engine.HollowReadStateEngine
-
- HollowReadStateEngine(boolean, ArraySegmentRecycler) - Constructor for class com.netflix.hollow.core.read.engine.HollowReadStateEngine
-
- HollowReadStateEngine(HollowObjectHashCodeFinder) - Constructor for class com.netflix.hollow.core.read.engine.HollowReadStateEngine
-
Deprecated.
- HollowReadStateEngine(HollowObjectHashCodeFinder, boolean, ArraySegmentRecycler) - Constructor for class com.netflix.hollow.core.read.engine.HollowReadStateEngine
-
Deprecated.
- HollowRecord - Interface in com.netflix.hollow.api.objects
-
A HollowRecord is the base interface for accessing data from any kind of record
in a Hollow dataset.
- HollowRecordCollection<T> - Class in com.netflix.hollow.core.util
-
- HollowRecordCollection(BitSet) - Constructor for class com.netflix.hollow.core.util.HollowRecordCollection
-
- HollowRecordCopier - Class in com.netflix.hollow.core.write.copy
-
- HollowRecordCopier(HollowTypeReadState, HollowWriteRecord, OrdinalRemapper, boolean) - Constructor for class com.netflix.hollow.core.write.copy.HollowRecordCopier
-
- HollowRecordDelegate - Interface in com.netflix.hollow.api.objects.delegate
-
A HollowRecordDelegate is used by a generated Hollow Objects API to access data from the data model.
- HollowRecordJsonStringifier - Class in com.netflix.hollow.tools.stringifier
-
Produces JSON String representations of Hollow records.
- HollowRecordJsonStringifier() - Constructor for class com.netflix.hollow.tools.stringifier.HollowRecordJsonStringifier
-
- HollowRecordJsonStringifier(boolean, boolean) - Constructor for class com.netflix.hollow.tools.stringifier.HollowRecordJsonStringifier
-
- HollowRecordJsonStringifier(boolean, String...) - Constructor for class com.netflix.hollow.tools.stringifier.HollowRecordJsonStringifier
-
- HollowRecordStringifier - Class in com.netflix.hollow.tools.stringifier
-
Produces human-readable String representations of Hollow records.
- HollowRecordStringifier() - Constructor for class com.netflix.hollow.tools.stringifier.HollowRecordStringifier
-
- HollowRecordStringifier(boolean, boolean, boolean) - Constructor for class com.netflix.hollow.tools.stringifier.HollowRecordStringifier
-
- HollowSampler - Interface in com.netflix.hollow.api.sampling
-
- HollowSamplingDirector - Class in com.netflix.hollow.api.sampling
-
- HollowSamplingDirector() - Constructor for class com.netflix.hollow.api.sampling.HollowSamplingDirector
-
- HollowSchema - Class in com.netflix.hollow.core.schema
-
A HollowSchema defines the structure of a hollow data model.
- HollowSchema(String) - Constructor for class com.netflix.hollow.core.schema.HollowSchema
-
- HollowSchema.SchemaType - Enum in com.netflix.hollow.core.schema
-
- HollowSchema.SchemaType.UnrecognizedSchemaTypeException - Exception in com.netflix.hollow.core.schema
-
- HollowSchemaIdentifierMapper - Interface in com.netflix.hollow.core.write.objectmapper.flatrecords
-
Warning: Experimental.
- HollowSchemaParser - Class in com.netflix.hollow.core.schema
-
- HollowSchemaParser() - Constructor for class com.netflix.hollow.core.schema.HollowSchemaParser
-
- HollowSchemaSorter - Class in com.netflix.hollow.core.schema
-
- HollowSchemaSorter() - Constructor for class com.netflix.hollow.core.schema.HollowSchemaSorter
-
- HollowSet<T> - Class in com.netflix.hollow.api.objects
-
A HollowSet provides an implementation of the Set
interface over
a SET record in a Hollow dataset.
- HollowSet(HollowSetDelegate<T>, int) - Constructor for class com.netflix.hollow.api.objects.HollowSet
-
- HollowSetCachedDelegate<T> - Class in com.netflix.hollow.api.objects.delegate
-
- HollowSetCachedDelegate(HollowSetTypeDataAccess, int) - Constructor for class com.netflix.hollow.api.objects.delegate.HollowSetCachedDelegate
-
- HollowSetCachedDelegate(HollowSetTypeAPI, int) - Constructor for class com.netflix.hollow.api.objects.delegate.HollowSetCachedDelegate
-
- HollowSetCopier - Class in com.netflix.hollow.core.write.copy
-
- HollowSetCopier(HollowSetTypeReadState, OrdinalRemapper, boolean) - Constructor for class com.netflix.hollow.core.write.copy.HollowSetCopier
-
- HollowSetDelegate<T> - Interface in com.netflix.hollow.api.objects.delegate
-
- HollowSetDeltaHistoricalStateCreator - Class in com.netflix.hollow.core.read.engine.set
-
This class contains the logic for extracting the removed records from an SET type state
to produce a historical type state.
- HollowSetDeltaHistoricalStateCreator(HollowSetTypeReadState) - Constructor for class com.netflix.hollow.core.read.engine.set.HollowSetDeltaHistoricalStateCreator
-
- HollowSetDisabledDataAccess - Class in com.netflix.hollow.core.read.dataaccess.disabled
-
- HollowSetJavaGenerator - Class in com.netflix.hollow.api.codegen.objects
-
This class contains template logic for generating a
HollowAPI
implementation.
- HollowSetJavaGenerator(String, String, HollowSetSchema, Set<String>, boolean, HollowDataset, CodeGeneratorConfig) - Constructor for class com.netflix.hollow.api.codegen.objects.HollowSetJavaGenerator
-
- HollowSetLookupDelegate<T> - Class in com.netflix.hollow.api.objects.delegate
-
- HollowSetLookupDelegate(HollowSetTypeDataAccess) - Constructor for class com.netflix.hollow.api.objects.delegate.HollowSetLookupDelegate
-
- HollowSetLookupDelegate(HollowSetTypeAPI) - Constructor for class com.netflix.hollow.api.objects.delegate.HollowSetLookupDelegate
-
- HollowSetMissingDataAccess - Class in com.netflix.hollow.core.read.dataaccess.missing
-
Used when an entire SET type, which is expected by a Generated Hollow API, is missing from the actual data.
- HollowSetMissingDataAccess(HollowDataAccess, String) - Constructor for class com.netflix.hollow.core.read.dataaccess.missing.HollowSetMissingDataAccess
-
- HollowSetOrdinalIterator - Class in com.netflix.hollow.core.read.iterator
-
- HollowSetOrdinalIterator(int, HollowSetTypeDataAccess) - Constructor for class com.netflix.hollow.core.read.iterator.HollowSetOrdinalIterator
-
- HollowSetProxyDataAccess - Class in com.netflix.hollow.core.read.dataaccess.proxy
-
- HollowSetProxyDataAccess(HollowProxyDataAccess) - Constructor for class com.netflix.hollow.core.read.dataaccess.proxy.HollowSetProxyDataAccess
-
- HollowSetSampler - Class in com.netflix.hollow.api.sampling
-
- HollowSetSampler(String, HollowSamplingDirector) - Constructor for class com.netflix.hollow.api.sampling.HollowSetSampler
-
- HollowSetSchema - Class in com.netflix.hollow.core.schema
-
A schema for a Set record type.
- HollowSetSchema(String, String, String...) - Constructor for class com.netflix.hollow.core.schema.HollowSetSchema
-
- HollowSetTypeAPI - Class in com.netflix.hollow.api.custom
-
This is the Hollow Type API interface for SET type records.
- HollowSetTypeAPI(HollowAPI, HollowSetTypeDataAccess) - Constructor for class com.netflix.hollow.api.custom.HollowSetTypeAPI
-
- HollowSetTypeDataAccess - Interface in com.netflix.hollow.core.read.dataaccess
-
A handle for all of the records of a specific SET type in a Hollow dataset.
- HollowSetTypeDataElements - Class in com.netflix.hollow.core.read.engine.set
-
- HollowSetTypeDataElements(ArraySegmentRecycler) - Constructor for class com.netflix.hollow.core.read.engine.set.HollowSetTypeDataElements
-
- HollowSetTypeDataElements(MemoryMode, ArraySegmentRecycler) - Constructor for class com.netflix.hollow.core.read.engine.set.HollowSetTypeDataElements
-
- HollowSetTypeMapper - Class in com.netflix.hollow.core.write.objectmapper
-
- HollowSetTypeMapper(HollowObjectMapper, ParameterizedType, String, String[], int, HollowWriteStateEngine, boolean, Set<Type>) - Constructor for class com.netflix.hollow.core.write.objectmapper.HollowSetTypeMapper
-
- HollowSetTypeReadState - Class in com.netflix.hollow.core.read.engine.set
-
- HollowSetTypeReadState(HollowReadStateEngine, HollowSetSchema, int) - Constructor for class com.netflix.hollow.core.read.engine.set.HollowSetTypeReadState
-
- HollowSetTypeReadState(HollowReadStateEngine, MemoryMode, HollowSetSchema, int) - Constructor for class com.netflix.hollow.core.read.engine.set.HollowSetTypeReadState
-
- HollowSetTypeWriteState - Class in com.netflix.hollow.core.write
-
- HollowSetTypeWriteState(HollowSetSchema) - Constructor for class com.netflix.hollow.core.write.HollowSetTypeWriteState
-
- HollowSetTypeWriteState(HollowSetSchema, int) - Constructor for class com.netflix.hollow.core.write.HollowSetTypeWriteState
-
- HollowSetWriteRecord - Class in com.netflix.hollow.core.write
-
- HollowSetWriteRecord() - Constructor for class com.netflix.hollow.core.write.HollowSetWriteRecord
-
- HollowSetWriteRecord(HollowHashableWriteRecord.HashBehavior) - Constructor for class com.netflix.hollow.core.write.HollowSetWriteRecord
-
- HollowShardLargeType - Annotation Type in com.netflix.hollow.core.write.objectmapper
-
Indicates how many shards are used to encode hollow records, in effect
partitioning records into P
parts corresponding to the number of
shards.
- HollowSparseIntegerSet - Class in com.netflix.hollow.core.index
-
Create hollow integer set for sparse non-negative & unique integer values referenced by fieldPath in a type based on a predicate.
- HollowSparseIntegerSet(HollowReadStateEngine, String, String) - Constructor for class com.netflix.hollow.core.index.HollowSparseIntegerSet
-
Create a index for integer values pointed by the given field path.
- HollowSparseIntegerSet(HollowReadStateEngine, String, String, HollowSparseIntegerSet.IndexPredicate) - Constructor for class com.netflix.hollow.core.index.HollowSparseIntegerSet
-
Create a index for integer values based on the given IndexPredicate.
- HollowSparseIntegerSet.IndexPredicate - Interface in com.netflix.hollow.core.index
-
- HollowSpecificDiff - Class in com.netflix.hollow.tools.diff.specific
-
The HollowSpecificDiff allows for the investigation of diffs among specific fields for matched records in two states.
- HollowSpecificDiff(HollowReadStateEngine, HollowReadStateEngine, String) - Constructor for class com.netflix.hollow.tools.diff.specific.HollowSpecificDiff
-
- HollowSplitter - Class in com.netflix.hollow.tools.split
-
This tool can be used to shard a Hollow dataset into two or more smaller datasets.
- HollowSplitter(HollowSplitterCopyDirector, HollowReadStateEngine) - Constructor for class com.netflix.hollow.tools.split.HollowSplitter
-
- HollowSplitterCopyDirector - Interface in com.netflix.hollow.tools.split
-
- HollowSplitterOrdinalCopyDirector - Class in com.netflix.hollow.tools.split
-
- HollowSplitterOrdinalCopyDirector(int, String...) - Constructor for class com.netflix.hollow.tools.split.HollowSplitterOrdinalCopyDirector
-
- HollowSplitterOrdinalRemapper - Class in com.netflix.hollow.tools.split
-
- HollowSplitterOrdinalRemapper(HollowReadStateEngine, HollowSplitterShardCopier) - Constructor for class com.netflix.hollow.tools.split.HollowSplitterOrdinalRemapper
-
- HollowSplitterPrimaryKeyCopyDirector - Class in com.netflix.hollow.tools.split
-
- HollowSplitterPrimaryKeyCopyDirector(HollowReadStateEngine, int, PrimaryKey...) - Constructor for class com.netflix.hollow.tools.split.HollowSplitterPrimaryKeyCopyDirector
-
- HollowSplitterShardCopier - Class in com.netflix.hollow.tools.split
-
- HollowSplitterShardCopier(HollowReadStateEngine, HollowWriteStateEngine, HollowSplitterCopyDirector, int) - Constructor for class com.netflix.hollow.tools.split.HollowSplitterShardCopier
-
- HollowStateDeltaPatcher - Class in com.netflix.hollow.tools.patch.delta
-
The HollowStateDeltaPatcher will create delta blobs which patch between two arbitrary states in a contiguous delta state chain.
- HollowStateDeltaPatcher(HollowReadStateEngine, HollowReadStateEngine) - Constructor for class com.netflix.hollow.tools.patch.delta.HollowStateDeltaPatcher
-
Create a delta patcher which will patch between the states contained in the two state engines.
- HollowStateEngine - Interface in com.netflix.hollow.core
-
A dataset changes over time.
- HollowStateEngineRecordPatcher - Class in com.netflix.hollow.tools.patch.record
-
This tool can be used to create a state with most records coming from a "base" state, but selected records
coming from a "patch" state.
- HollowStateEngineRecordPatcher(HollowReadStateEngine, HollowReadStateEngine) - Constructor for class com.netflix.hollow.tools.patch.record.HollowStateEngineRecordPatcher
-
- HollowStateEngineRecordPatcher(HollowReadStateEngine, HollowReadStateEngine, boolean) - Constructor for class com.netflix.hollow.tools.patch.record.HollowStateEngineRecordPatcher
-
- HollowStringifier<T extends HollowStringifier> - Interface in com.netflix.hollow.tools.stringifier
-
- HollowTransient - Annotation Type in com.netflix.hollow.core.write.objectmapper
-
Indicates that a field of a POJO is to be ignored.
- HollowTypeAPI - Class in com.netflix.hollow.api.custom
-
A Hollow Type API provides methods for accessing data in Hollow records without creating
wrapper objects as handles.
- HollowTypeAPI(HollowAPI, HollowTypeDataAccess) - Constructor for class com.netflix.hollow.api.custom.HollowTypeAPI
-
- HollowTypeAPIGenerator - Class in com.netflix.hollow.api.codegen.api
-
- HollowTypeAPIGenerator(String, String, HollowSchema, HollowDataset, CodeGeneratorConfig) - Constructor for class com.netflix.hollow.api.codegen.api.HollowTypeAPIGenerator
-
- HollowTypeDataAccess - Interface in com.netflix.hollow.core.read.dataaccess
-
A handle for all of the records of a specific type in a Hollow dataset.
- HollowTypeDiff - Class in com.netflix.hollow.tools.diff
-
Obtained via a
HollowDiff
, this is a report of the differences in a specific type between two data states.
- HollowTypeMapper - Class in com.netflix.hollow.core.write.objectmapper
-
- HollowTypeMapper() - Constructor for class com.netflix.hollow.core.write.objectmapper.HollowTypeMapper
-
- HollowTypeName - Annotation Type in com.netflix.hollow.core.write.objectmapper
-
Indicates the hollow type name of a POJO or the hollow field name of a field
declared by a POJO.
- HollowTypeProxyDataAccess - Class in com.netflix.hollow.core.read.dataaccess.proxy
-
- HollowTypeProxyDataAccess(HollowProxyDataAccess) - Constructor for class com.netflix.hollow.core.read.dataaccess.proxy.HollowTypeProxyDataAccess
-
- HollowTypeReadState - Class in com.netflix.hollow.core.read.engine
-
A HollowTypeReadState contains and is the root handle to all of the records of a specific type in
a
HollowReadStateEngine
.
- HollowTypeReadState(HollowReadStateEngine, MemoryMode, HollowSchema) - Constructor for class com.netflix.hollow.core.read.engine.HollowTypeReadState
-
- HollowTypeStateListener - Interface in com.netflix.hollow.core.read.engine
-
- HollowTypeWriteState - Class in com.netflix.hollow.core.write
-
- HollowTypeWriteState(HollowSchema, int) - Constructor for class com.netflix.hollow.core.write.HollowTypeWriteState
-
- HollowUniqueKeyIndex<T> - Interface in com.netflix.hollow.api.consumer.index
-
- HollowUniqueKeyIndexGenerator - Class in com.netflix.hollow.api.codegen.indexes
-
This class contains template logic for generating a
HollowAPI
implementation.
- HollowUniqueKeyIndexGenerator(String, String, HollowObjectSchema, HollowDataset, CodeGeneratorConfig) - Constructor for class com.netflix.hollow.api.codegen.indexes.HollowUniqueKeyIndexGenerator
-
- HollowUnsafeHandle - Class in com.netflix.hollow.core.memory
-
- HollowUnsafeHandle() - Constructor for class com.netflix.hollow.core.memory.HollowUnsafeHandle
-
- HollowUpdateListener - Interface in com.netflix.hollow.api.client
-
- HollowUpdatePlan - Class in com.netflix.hollow.api.client
-
A plan, containing one or more HollowConsumer.Blob
s, which will be used to update the current data state to a desired data state.
- HollowUpdatePlan() - Constructor for class com.netflix.hollow.api.client.HollowUpdatePlan
-
- HollowUpdatePlanner - Class in com.netflix.hollow.api.client
-
- HollowUpdatePlanner(HollowBlobRetriever) - Constructor for class com.netflix.hollow.api.client.HollowUpdatePlanner
-
Deprecated.
- HollowUpdatePlanner(HollowConsumer.BlobRetriever) - Constructor for class com.netflix.hollow.api.client.HollowUpdatePlanner
-
- HollowUpdatePlanner(HollowConsumer.BlobRetriever, HollowConsumer.DoubleSnapshotConfig) - Constructor for class com.netflix.hollow.api.client.HollowUpdatePlanner
-
- HollowWriteRecord - Interface in com.netflix.hollow.core.write
-
- HollowWriteStateCreator - Class in com.netflix.hollow.core.util
-
- HollowWriteStateCreator() - Constructor for class com.netflix.hollow.core.util.HollowWriteStateCreator
-
- HollowWriteStateEngine - Class in com.netflix.hollow.core.write
-
- HollowWriteStateEngine() - Constructor for class com.netflix.hollow.core.write.HollowWriteStateEngine
-
- HollowWriteStateEngine(HollowObjectHashCodeFinder) - Constructor for class com.netflix.hollow.core.write.HollowWriteStateEngine
-
Deprecated.
- HollowWriteStateException - Exception in com.netflix.hollow.api.error
-
An exception thrown when the write state is unable to advance, revert, or otherwise fails.
- HollowWriteStateException(String) - Constructor for exception com.netflix.hollow.api.error.HollowWriteStateException
-
- HollowWriteStateException(String, Throwable) - Constructor for exception com.netflix.hollow.api.error.HollowWriteStateException
-
- HollowWriteStateException(Throwable) - Constructor for exception com.netflix.hollow.api.error.HollowWriteStateException
-
- HString - Class in com.netflix.hollow.core.type
-
- HString(StringDelegate, int) - Constructor for class com.netflix.hollow.core.type.HString
-
- ObjectFilterConfig() - Constructor for class com.netflix.hollow.core.read.filter.HollowFilterConfig.ObjectFilterConfig
-
Deprecated.
- ObjectFilterConfig(Boolean) - Constructor for class com.netflix.hollow.core.read.filter.HollowFilterConfig.ObjectFilterConfig
-
Deprecated.
- objectLongevityConfig - Variable in class com.netflix.hollow.api.consumer.HollowConsumer.Builder
-
- objectLongevityDetector - Variable in class com.netflix.hollow.api.consumer.HollowConsumer.Builder
-
- ObjectModificationValidator<A extends HollowAPI,T extends HollowObject> - Class in com.netflix.hollow.api.producer.validation
-
This validator runs a provided BiPredicate
on every instance of an object that was
modified in a cycle.
- ObjectModificationValidator(String, BiPredicate<T, T>, Function<HollowDataAccess, A>, BiFunction<A, Integer, T>) - Constructor for class com.netflix.hollow.api.producer.validation.ObjectModificationValidator
-
- objects() - Method in class com.netflix.hollow.api.objects.generic.GenericHollowList
-
- objects() - Method in class com.netflix.hollow.api.objects.generic.GenericHollowSet
-
- onAfterRemoval(HollowConsumer) - Method in interface com.netflix.hollow.api.consumer.HollowConsumer.RefreshRegistrationListener
-
Called after the refresh listener is removed.
- onAfterRemoval(HollowConsumer) - Method in class com.netflix.hollow.api.consumer.index.HashIndexSelect
-
- onAfterRemoval(HollowConsumer) - Method in class com.netflix.hollow.api.consumer.index.UniqueKeyIndex
-
- onAnnouncementComplete(HollowProducerListener.ProducerStatus, long, TimeUnit) - Method in class com.netflix.hollow.api.producer.AbstractHollowProducerListener
-
- onAnnouncementComplete(Status, HollowProducer.ReadState, long, Duration) - Method in interface com.netflix.hollow.api.producer.HollowProducerListener
-
- onAnnouncementComplete(HollowProducerListener.ProducerStatus, long, TimeUnit) - Method in interface com.netflix.hollow.api.producer.HollowProducerListener
-
Called after the announcement stage finishes normally or abnormally.
- onAnnouncementComplete(Status, HollowProducer.ReadState, long, Duration) - Method in interface com.netflix.hollow.api.producer.listener.AnnouncementListener
-
Called after the announcement stage finishes normally or abnormally.
- onAnnouncementComplete(Status, HollowProducer.ReadState, long, Duration) - Method in class com.netflix.hollow.api.producer.metrics.AbstractProducerMetricsListener
-
Reports announcement-related metrics.
- onAnnouncementStart(long) - Method in class com.netflix.hollow.api.producer.AbstractHollowProducerListener
-
- onAnnouncementStart(HollowProducer.ReadState) - Method in class com.netflix.hollow.api.producer.AbstractHollowProducerListener
-
- onAnnouncementStart(long) - Method in interface com.netflix.hollow.api.producer.HollowProducerListener
-
Called when the HollowProducer
has begun announcing the HollowBlob
published this cycle.
- onAnnouncementStart(long) - Method in interface com.netflix.hollow.api.producer.listener.AnnouncementListener
-
Called when the HollowProducer
has begun announcing the HollowBlob
published this cycle.
- onAnnouncementStart(HollowProducer.ReadState) - Method in interface com.netflix.hollow.api.producer.listener.AnnouncementListener
-
Called when the HollowProducer
has begun announcing the HollowBlob
published this cycle.
- onAnnouncementStart(long) - Method in class com.netflix.hollow.api.producer.metrics.AbstractProducerMetricsListener
-
- onArtifactPublish(HollowProducerListener.PublishStatus, long, TimeUnit) - Method in class com.netflix.hollow.api.producer.AbstractHollowProducerListener
-
- onArtifactPublish(HollowProducerListener.PublishStatus, long, TimeUnit) - Method in interface com.netflix.hollow.api.producer.HollowProducerListener
-
Called once a blob has been published successfully or failed to published.
- onBeforeAddition(HollowConsumer) - Method in interface com.netflix.hollow.api.consumer.HollowConsumer.RefreshRegistrationListener
-
Called before the refresh listener is added.
- onBeforeAddition(HollowConsumer) - Method in class com.netflix.hollow.api.consumer.index.HashIndexSelect
-
- onBeforeAddition(HollowConsumer) - Method in class com.netflix.hollow.api.consumer.index.UniqueKeyIndex
-
- onBlobPublish(Status, HollowProducer.Blob, Duration) - Method in interface com.netflix.hollow.api.producer.HollowProducerListener
-
- onBlobPublish(Status, HollowProducer.Blob, Duration) - Method in interface com.netflix.hollow.api.producer.listener.PublishListener
-
Called once a blob has been published successfully or failed to published.
- onBlobPublishAsync(CompletableFuture<HollowProducer.Blob>) - Method in interface com.netflix.hollow.api.producer.listener.PublishListener
-
Called if a blob is to be published asynchronously.
- onBlobStage(Status, HollowProducer.Blob, Duration) - Method in interface com.netflix.hollow.api.producer.listener.PublishListener
-
Called once a blob has been staged successfully or failed to stage.
- onCycleComplete(HollowProducerListener.ProducerStatus, long, TimeUnit) - Method in class com.netflix.hollow.api.producer.AbstractHollowProducerListener
-
- onCycleComplete(IncrementalCycleListener.IncrementalCycleStatus, long, TimeUnit) - Method in class com.netflix.hollow.api.producer.AbstractIncrementalCycleListener
-
Deprecated.
- onCycleComplete(HollowProducerListener.ProducerStatus, long, TimeUnit) - Method in class com.netflix.hollow.api.producer.enforcer.AbstractSingleProducerEnforcer
-
- onCycleComplete(Status, HollowProducer.ReadState, long, Duration) - Method in interface com.netflix.hollow.api.producer.HollowProducerListener
-
- onCycleComplete(HollowProducerListener.ProducerStatus, long, TimeUnit) - Method in interface com.netflix.hollow.api.producer.HollowProducerListener
-
Called after HollowProducer
has completed a cycle normally or abnormally.
- onCycleComplete(IncrementalCycleListener.IncrementalCycleStatus, long, TimeUnit) - Method in interface com.netflix.hollow.api.producer.IncrementalCycleListener
-
Deprecated.
Called after HollowIncrementalProducer
has completed a cycle normally or abnormally.
- onCycleComplete(Status, HollowProducer.ReadState, long, Duration) - Method in interface com.netflix.hollow.api.producer.listener.CycleListener
-
A receiver of a cycle complete event.
- onCycleComplete(Status, HollowProducer.ReadState, long, Duration) - Method in class com.netflix.hollow.api.producer.metrics.AbstractProducerMetricsListener
-
On cycle completion this method reports cycle metrics.
- onCycleFail(IncrementalCycleListener.IncrementalCycleStatus, long, TimeUnit) - Method in class com.netflix.hollow.api.producer.AbstractIncrementalCycleListener
-
Deprecated.
- onCycleFail(IncrementalCycleListener.IncrementalCycleStatus, long, TimeUnit) - Method in interface com.netflix.hollow.api.producer.IncrementalCycleListener
-
Deprecated.
Called after HollowIncrementalProducer
has completed a cycle normally or abnormally.
- onCycleSkip(CycleListener.CycleSkipReason) - Method in class com.netflix.hollow.api.producer.AbstractHollowProducerListener
-
- onCycleSkip(CycleListener.CycleSkipReason) - Method in interface com.netflix.hollow.api.producer.HollowProducerListener
-
- onCycleSkip(CycleListener.CycleSkipReason) - Method in interface com.netflix.hollow.api.producer.listener.CycleListener
-
A receiver of a cycle skip event.
- onCycleSkip(CycleListener.CycleSkipReason) - Method in class com.netflix.hollow.api.producer.metrics.AbstractProducerMetricsListener
-
Reports metrics for when cycle is skipped due to reasons such as the producer not being the leader in a multiple-producer setting.
- onCycleStart(long) - Method in class com.netflix.hollow.api.producer.AbstractHollowProducerListener
-
- onCycleStart(long) - Method in class com.netflix.hollow.api.producer.enforcer.AbstractSingleProducerEnforcer
-
- onCycleStart(long) - Method in interface com.netflix.hollow.api.producer.HollowProducerListener
-
Called when the HollowProducer
has begun a new cycle.
- onCycleStart(long) - Method in interface com.netflix.hollow.api.producer.listener.CycleListener
-
A receiver of a cycle start event.
- ONE_HOUR - Static variable in interface com.netflix.hollow.api.client.HollowClientMemoryConfig
-
Deprecated.
- onIncrementalPopulateComplete(Status, long, long, long, Duration) - Method in interface com.netflix.hollow.api.producer.listener.IncrementalPopulateListener
-
Called once the incremental populating task stage has finished successfully or failed.
- onIncrementalPopulateStart(long) - Method in interface com.netflix.hollow.api.producer.listener.IncrementalPopulateListener
-
Called before starting to execute the task to incrementally populate data into Hollow.
- onIntegrityCheckComplete(HollowProducerListener.ProducerStatus, long, TimeUnit) - Method in class com.netflix.hollow.api.producer.AbstractHollowProducerListener
-
- onIntegrityCheckComplete(Status, HollowProducer.ReadState, long, Duration) - Method in interface com.netflix.hollow.api.producer.HollowProducerListener
-
- onIntegrityCheckComplete(HollowProducerListener.ProducerStatus, long, TimeUnit) - Method in interface com.netflix.hollow.api.producer.HollowProducerListener
-
Called after the integrity check stage finishes normally or abnormally.
- onIntegrityCheckComplete(Status, HollowProducer.ReadState, long, Duration) - Method in interface com.netflix.hollow.api.producer.listener.IntegrityCheckListener
-
Called after the integrity check stage finishes normally or abnormally.
- onIntegrityCheckStart(long) - Method in class com.netflix.hollow.api.producer.AbstractHollowProducerListener
-
- onIntegrityCheckStart(long) - Method in interface com.netflix.hollow.api.producer.HollowProducerListener
-
Called when the HollowProducer
has begun checking the integrity of the HollowBlob
s produced this cycle.
- onIntegrityCheckStart(long) - Method in interface com.netflix.hollow.api.producer.listener.IntegrityCheckListener
-
Called when the HollowProducer
has begun checking the integrity of the HollowBlob
s produced this cycle.
- onNewDeltaChain(long) - Method in class com.netflix.hollow.api.producer.AbstractHollowProducerListener
-
- onNewDeltaChain(long) - Method in interface com.netflix.hollow.api.producer.HollowProducerListener
-
Indicates that the next state produced will begin a new delta chain.
- onNewDeltaChain(long) - Method in interface com.netflix.hollow.api.producer.listener.CycleListener
-
A receiver of a new delta chain event.
- onNoDeltaAvailable(long) - Method in class com.netflix.hollow.api.producer.AbstractHollowProducerListener
-
- onNoDeltaAvailable(long) - Method in interface com.netflix.hollow.api.producer.HollowProducerListener
-
Called after the new state has been populated if the HollowProducer
detects that no data has changed, thus no snapshot nor delta should be produced.
- onNoDeltaAvailable(long) - Method in interface com.netflix.hollow.api.producer.listener.PublishListener
-
Called after the new state has been populated if the HollowProducer
detects that no data has changed,
thus no snapshot nor delta should be produced.
- onPopulateComplete(HollowProducerListener.ProducerStatus, long, TimeUnit) - Method in class com.netflix.hollow.api.producer.AbstractHollowProducerListener
-
- onPopulateComplete(Status, long, Duration) - Method in interface com.netflix.hollow.api.producer.HollowProducerListener
-
- onPopulateComplete(HollowProducerListener.ProducerStatus, long, TimeUnit) - Method in interface com.netflix.hollow.api.producer.HollowProducerListener
-
Called once populating task stage has finished successfully or failed.
- onPopulateComplete(Status, long, Duration) - Method in interface com.netflix.hollow.api.producer.listener.PopulateListener
-
Called once the populating task stage has finished successfully or failed.
- onPopulateStart(long) - Method in class com.netflix.hollow.api.producer.AbstractHollowProducerListener
-
- onPopulateStart(long) - Method in interface com.netflix.hollow.api.producer.HollowProducerListener
-
Called before starting to execute the task to populate data into Hollow.
- onPopulateStart(long) - Method in interface com.netflix.hollow.api.producer.listener.PopulateListener
-
Called before starting to execute the task to populate data into Hollow.
- onProducerInit(long, TimeUnit) - Method in class com.netflix.hollow.api.producer.AbstractHollowProducerListener
-
- onProducerInit(Duration) - Method in interface com.netflix.hollow.api.producer.HollowProducerListener
-
- onProducerInit(long, TimeUnit) - Method in interface com.netflix.hollow.api.producer.HollowProducerListener
-
Called after the HollowProducer
has initialized its data model.
- onProducerInit(Duration) - Method in interface com.netflix.hollow.api.producer.listener.DataModelInitializationListener
-
Called after the HollowProducer
has initialized its data model.
- onProducerRestoreComplete(HollowProducerListener.RestoreStatus, long, TimeUnit) - Method in class com.netflix.hollow.api.producer.AbstractHollowProducerListener
-
- onProducerRestoreComplete(Status, long, long, Duration) - Method in interface com.netflix.hollow.api.producer.HollowProducerListener
-
- onProducerRestoreComplete(HollowProducerListener.RestoreStatus, long, TimeUnit) - Method in interface com.netflix.hollow.api.producer.HollowProducerListener
-
Called after the HollowProducer
has restored its data state to the indicated version.
- onProducerRestoreComplete(Status, long, long, Duration) - Method in interface com.netflix.hollow.api.producer.listener.RestoreListener
-
Called after the HollowProducer
has restored its data state to the indicated version.
- onProducerRestoreStart(long) - Method in class com.netflix.hollow.api.producer.AbstractHollowProducerListener
-
- onProducerRestoreStart(long) - Method in interface com.netflix.hollow.api.producer.HollowProducerListener
-
Called after the HollowProducer
has restored its data state to the indicated version.
- onProducerRestoreStart(long) - Method in interface com.netflix.hollow.api.producer.listener.RestoreListener
-
Called after the HollowProducer
has restored its data state to the indicated version.
- onPublishComplete(HollowProducerListener.ProducerStatus, long, TimeUnit) - Method in class com.netflix.hollow.api.producer.AbstractHollowProducerListener
-
- onPublishComplete(Status, long, Duration) - Method in interface com.netflix.hollow.api.producer.HollowProducerListener
-
- onPublishComplete(HollowProducerListener.ProducerStatus, long, TimeUnit) - Method in interface com.netflix.hollow.api.producer.HollowProducerListener
-
Called after the publish stage finishes normally or abnormally.
- onPublishComplete(Status, long, Duration) - Method in interface com.netflix.hollow.api.producer.listener.PublishListener
-
Called after the publish stage finishes normally or abnormally.
- onPublishStart(long) - Method in class com.netflix.hollow.api.producer.AbstractHollowProducerListener
-
- onPublishStart(long) - Method in interface com.netflix.hollow.api.producer.HollowProducerListener
-
Called when the HollowProducer
has begun publishing the HollowBlob
s produced this cycle.
- onPublishStart(long) - Method in interface com.netflix.hollow.api.producer.listener.PublishListener
-
Called when the HollowProducer
has begun publishing the HollowBlob
s produced this cycle.
- onValidate(HollowProducer.ReadState) - Method in class com.netflix.hollow.api.producer.validation.DuplicateDataDetectionValidator
-
- onValidate(HollowProducer.ReadState) - Method in class com.netflix.hollow.api.producer.validation.ObjectModificationValidator
-
- onValidate(HollowProducer.ReadState) - Method in class com.netflix.hollow.api.producer.validation.RecordCountVarianceValidator
-
- onValidate(HollowProducer.ReadState) - Method in interface com.netflix.hollow.api.producer.validation.ValidatorListener
-
A receiver of a validation event.
- onValidationComplete(HollowProducerListener.ProducerStatus, long, TimeUnit) - Method in class com.netflix.hollow.api.producer.AbstractHollowProducerListener
-
- onValidationComplete(HollowProducerListener.ProducerStatus, long, TimeUnit) - Method in interface com.netflix.hollow.api.producer.HollowProducerListener
-
Called after the validation stage finishes normally or abnormally.
- onValidationStart(long) - Method in class com.netflix.hollow.api.producer.AbstractHollowProducerListener
-
- onValidationStart(long) - Method in interface com.netflix.hollow.api.producer.HollowProducerListener
-
Called when the HollowProducer
has begun validating the new data state produced this cycle.
- onValidationStatusComplete(ValidationStatus, long, Duration) - Method in interface com.netflix.hollow.api.producer.validation.ValidationStatusListener
-
A receiver of a validation status complete event.
- onValidationStatusStart(long) - Method in interface com.netflix.hollow.api.producer.validation.ValidationStatusListener
-
A receiver of a validation status start event.
- openDelta(long, long) - Method in class com.netflix.hollow.api.producer.fs.HollowFilesystemBlobStager
-
- openDelta(long, long) - Method in class com.netflix.hollow.api.producer.fs.HollowInMemoryBlobStager
-
- openDelta(long, long) - Method in interface com.netflix.hollow.api.producer.HollowProducer.BlobStager
-
Returns a blob with which a HollowProducer
will write a forward delta from the version specified to
the version specified, i.e.
- openReverseDelta(long, long) - Method in class com.netflix.hollow.api.producer.fs.HollowFilesystemBlobStager
-
- openReverseDelta(long, long) - Method in class com.netflix.hollow.api.producer.fs.HollowInMemoryBlobStager
-
- openReverseDelta(long, long) - Method in interface com.netflix.hollow.api.producer.HollowProducer.BlobStager
-
Returns a blob with which a HollowProducer
will write a reverse delta from the version specified to
the version specified, i.e.
- openSnapshot(long) - Method in class com.netflix.hollow.api.producer.fs.HollowFilesystemBlobStager
-
- openSnapshot(long) - Method in class com.netflix.hollow.api.producer.fs.HollowInMemoryBlobStager
-
- openSnapshot(long) - Method in interface com.netflix.hollow.api.producer.HollowProducer.BlobStager
-
Returns a blob with which a HollowProducer
will write a snapshot for the version specified.
- OptionalBlobPartInput - Class in com.netflix.hollow.core.read
-
- OptionalBlobPartInput() - Constructor for class com.netflix.hollow.core.read.OptionalBlobPartInput
-
- optionalPartConfig - Variable in class com.netflix.hollow.api.producer.fs.HollowFilesystemBlobStager
-
- optionalPartConfig - Variable in class com.netflix.hollow.api.producer.HollowProducer.Blob
-
- optionalPartPaths - Variable in class com.netflix.hollow.api.producer.fs.HollowFilesystemBlobStager.FilesystemBlob
-
- orAll(ThreadSafeBitSet...) - Static method in class com.netflix.hollow.core.memory.ThreadSafeBitSet
-
Return a new bit set which contains all bits which are contained in *any* of the specified bit sets.
- orderedCopy(VariableLengthData, long, long, long) - Method in class com.netflix.hollow.core.memory.EncodedByteBuffer
-
- orderedCopy(VariableLengthData, long, long, long) - Method in class com.netflix.hollow.core.memory.SegmentedByteArray
-
- orderedCopy(VariableLengthData, long, long, long) - Method in interface com.netflix.hollow.core.memory.VariableLengthData
-
Copies data from the provided source into destination, guaranteeing that if the update is seen
by another thread, then all other writes prior to this call are also visible to that thread.
- ordinal - Variable in class com.netflix.hollow.api.objects.HollowList
-
- ordinal - Variable in class com.netflix.hollow.api.objects.HollowMap
-
- ordinal - Variable in class com.netflix.hollow.api.objects.HollowObject
-
- ordinal - Variable in class com.netflix.hollow.api.objects.HollowSet
-
- ORDINAL_NONE - Static variable in interface com.netflix.hollow.core.HollowConstants
-
An ordinal of NULL_ORDINAL signifies "null reference" or "no ordinal"
- ordinalIsMapped(String, int) - Method in class com.netflix.hollow.tools.combine.HollowCombinerOrdinalRemapper
-
- ordinalIsMapped(String, int) - Method in class com.netflix.hollow.tools.combine.IdentityOrdinalRemapper
-
- ordinalIsMapped(String, int) - Method in interface com.netflix.hollow.tools.combine.OrdinalRemapper
-
- ordinalIsMapped(String, int) - Method in class com.netflix.hollow.tools.history.DiffEqualityMappingOrdinalRemapper
-
- ordinalIsMapped(String, int) - Method in class com.netflix.hollow.tools.history.IntMapOrdinalRemapper
-
- ordinalIsMapped(String, int) - Method in class com.netflix.hollow.tools.patch.delta.PartialOrdinalRemapper
-
- ordinalIsMapped(String, int) - Method in class com.netflix.hollow.tools.split.HollowSplitterOrdinalRemapper
-
- ordinalIsPresent(int) - Method in class com.netflix.hollow.tools.history.HollowHistoricalTypeDataAccess
-
- ordinalIterator(int) - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowListDisabledDataAccess
-
- ordinalIterator(int) - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowMapDisabledDataAccess
-
- ordinalIterator(int) - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowSetDisabledDataAccess
-
- ordinalIterator(int) - Method in interface com.netflix.hollow.core.read.dataaccess.HollowCollectionTypeDataAccess
-
- ordinalIterator(int) - Method in interface com.netflix.hollow.core.read.dataaccess.HollowMapTypeDataAccess
-
- ordinalIterator(int) - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowListMissingDataAccess
-
- ordinalIterator(int) - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowMapMissingDataAccess
-
- ordinalIterator(int) - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowSetMissingDataAccess
-
- ordinalIterator(int) - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowListProxyDataAccess
-
- ordinalIterator(int) - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowMapProxyDataAccess
-
- ordinalIterator(int) - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowSetProxyDataAccess
-
- ordinalIterator(int) - Method in class com.netflix.hollow.core.read.engine.HollowCollectionTypeReadState
-
- ordinalIterator(int) - Method in class com.netflix.hollow.core.read.engine.list.HollowListTypeReadState
-
- ordinalIterator(int) - Method in class com.netflix.hollow.core.read.engine.map.HollowMapTypeReadState
-
- ordinalIterator(int) - Method in class com.netflix.hollow.core.read.engine.set.HollowSetTypeReadState
-
- ordinalIterator(int) - Method in class com.netflix.hollow.tools.history.HollowHistoricalListDataAccess
-
- ordinalIterator(int) - Method in class com.netflix.hollow.tools.history.HollowHistoricalMapDataAccess
-
- ordinalIterator(int) - Method in class com.netflix.hollow.tools.history.HollowHistoricalSetDataAccess
-
- ordinalMap - Variable in class com.netflix.hollow.core.write.HollowTypeWriteState
-
- ordinalRemap - Variable in class com.netflix.hollow.tools.history.HollowHistoricalTypeDataAccess
-
- ordinalRemapper - Variable in class com.netflix.hollow.core.write.copy.HollowRecordCopier
-
- OrdinalRemapper - Interface in com.netflix.hollow.tools.combine
-
Remaps ordinals various operations.
- overrideNextStateRandomizedTag(long) - Method in class com.netflix.hollow.core.write.HollowWriteStateEngine
-
- overridePreviousStateRandomizedTag(long) - Method in class com.netflix.hollow.core.write.HollowWriteStateEngine
-
- randomAccess(File) - Static method in class com.netflix.hollow.core.read.HollowBlobInput
-
Initialize a random access Hollow Blob input object from a file.
- randomAccess(File, int) - Static method in class com.netflix.hollow.core.read.HollowBlobInput
-
Useful for testing with custom buffer capacity
- rangeEquals(long, SegmentedByteArray, long, int) - Method in class com.netflix.hollow.core.memory.SegmentedByteArray
-
checks equality for a specified range of bytes in two arrays
- read() - Method in class com.netflix.hollow.core.read.HollowBlobInput
-
Reads the next byte of data from the input stream by relaying the call to the underlying DataInputStream
or
RandomAccessFile
.
- read(byte[], int, int) - Method in class com.netflix.hollow.core.read.HollowBlobInput
-
Reads up to len
bytes of data from the HollowBlobInput by relaying the call to the underlying
DataInputStream
or RandomAccessFile
into an array of bytes.
- readBoolean(int, int) - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowObjectDisabledDataAccess
-
- readBoolean(int, int) - Method in interface com.netflix.hollow.core.read.dataaccess.HollowObjectTypeDataAccess
-
- readBoolean(int, int) - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowObjectMissingDataAccess
-
- readBoolean(int, int) - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowObjectProxyDataAccess
-
- readBoolean(int, int) - Method in class com.netflix.hollow.core.read.engine.object.HollowObjectTypeReadState
-
- readBoolean(int, int) - Method in class com.netflix.hollow.tools.history.HollowHistoricalObjectDataAccess
-
- readBytes(int, int) - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowObjectDisabledDataAccess
-
- readBytes(int, int) - Method in interface com.netflix.hollow.core.read.dataaccess.HollowObjectTypeDataAccess
-
- readBytes(int, int) - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowObjectMissingDataAccess
-
- readBytes(int, int) - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowObjectProxyDataAccess
-
- readBytes(int, int) - Method in class com.netflix.hollow.core.read.engine.object.HollowObjectTypeReadState
-
- readBytes(int, int) - Method in class com.netflix.hollow.tools.history.HollowHistoricalObjectDataAccess
-
- readDouble(int, int) - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowObjectDisabledDataAccess
-
- readDouble(int, int) - Method in interface com.netflix.hollow.core.read.dataaccess.HollowObjectTypeDataAccess
-
- readDouble(int, int) - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowObjectMissingDataAccess
-
- readDouble(int, int) - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowObjectProxyDataAccess
-
- readDouble(int, int) - Method in class com.netflix.hollow.core.read.engine.object.HollowObjectTypeReadState
-
- readDouble(int, int) - Method in class com.netflix.hollow.tools.history.HollowHistoricalObjectDataAccess
-
- readEncodedDeltaOrdinals(HollowBlobInput, ArraySegmentRecycler) - Static method in class com.netflix.hollow.core.memory.encoding.GapEncodedVariableLengthIntegerReader
-
- readFloat(int, int) - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowObjectDisabledDataAccess
-
- readFloat(int, int) - Method in interface com.netflix.hollow.core.read.dataaccess.HollowObjectTypeDataAccess
-
- readFloat(int, int) - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowObjectMissingDataAccess
-
- readFloat(int, int) - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowObjectProxyDataAccess
-
- readFloat(int, int) - Method in class com.netflix.hollow.core.read.engine.object.HollowObjectTypeReadState
-
- readFloat(int, int) - Method in class com.netflix.hollow.tools.history.HollowHistoricalObjectDataAccess
-
- readFrom(HollowBlobInput, ArraySegmentRecycler, long) - Method in class com.netflix.hollow.core.memory.SegmentedLongArray
-
- readFrom(InputStream) - Static method in class com.netflix.hollow.core.schema.HollowSchema
-
- readFrom(HollowBlobInput) - Static method in class com.netflix.hollow.core.schema.HollowSchema
-
- readHeader(InputStream) - Method in class com.netflix.hollow.core.read.engine.HollowBlobHeaderReader
-
- readHeader(HollowBlobInput) - Method in class com.netflix.hollow.core.read.engine.HollowBlobHeaderReader
-
- readInt(int, int) - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowObjectDisabledDataAccess
-
- readInt(int, int) - Method in interface com.netflix.hollow.core.read.dataaccess.HollowObjectTypeDataAccess
-
- readInt(int, int) - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowObjectMissingDataAccess
-
- readInt(int, int) - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowObjectProxyDataAccess
-
- readInt(int, int) - Method in class com.netflix.hollow.core.read.engine.object.HollowObjectTypeReadState
-
- readInt() - Method in class com.netflix.hollow.core.read.HollowBlobInput
-
Reads 4 bytes from the input (at the current file pointer) into a signed 32-bit int, and advances the offset
in input.
- readInt(int, int) - Method in class com.netflix.hollow.tools.history.HollowHistoricalObjectDataAccess
-
- readIntBits(long) - Method in interface com.netflix.hollow.core.memory.ByteData
-
- readLong(int, int) - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowObjectDisabledDataAccess
-
- readLong(int, int) - Method in interface com.netflix.hollow.core.read.dataaccess.HollowObjectTypeDataAccess
-
- readLong(int, int) - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowObjectMissingDataAccess
-
- readLong(int, int) - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowObjectProxyDataAccess
-
- readLong(int, int) - Method in class com.netflix.hollow.core.read.engine.object.HollowObjectTypeReadState
-
- readLong() - Method in class com.netflix.hollow.core.read.HollowBlobInput
-
Reads 8 bytes from the input (at the current file pointer) into a signed 64-bit long, and advances the offset
in input.
- readLong(int, int) - Method in class com.netflix.hollow.tools.history.HollowHistoricalObjectDataAccess
-
- readLongBits(long) - Method in interface com.netflix.hollow.core.memory.ByteData
-
- readOrdinal(int, int) - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowObjectDisabledDataAccess
-
- readOrdinal(int, int) - Method in interface com.netflix.hollow.core.read.dataaccess.HollowObjectTypeDataAccess
-
- readOrdinal(int, int) - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowObjectMissingDataAccess
-
- readOrdinal(int, int) - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowObjectProxyDataAccess
-
- readOrdinal(int, int) - Method in class com.netflix.hollow.core.read.engine.object.HollowObjectTypeReadState
-
- readOrdinal(int, int) - Method in class com.netflix.hollow.tools.history.HollowHistoricalObjectDataAccess
-
- readOrdinals(HollowBlobInput, HollowTypeStateListener[]) - Static method in class com.netflix.hollow.core.read.engine.SnapshotPopulatedOrdinalsReader
-
Read populated ordinals as a bit set from a HollowBlobInput
, and notify a listener for each populated ordinal.
- readPartHeader(InputStream) - Method in class com.netflix.hollow.core.read.engine.HollowBlobHeaderReader
-
- readPartHeader(HollowBlobInput) - Method in class com.netflix.hollow.core.read.engine.HollowBlobHeaderReader
-
- readSchemaFileIntoWriteState(String, HollowWriteStateEngine) - Static method in class com.netflix.hollow.core.util.HollowWriteStateCreator
-
Reads a schema file into the provided HollowWriteStateEngine.
- readShort() - Method in class com.netflix.hollow.core.read.HollowBlobInput
-
Reads two bytes from the input (at the current file pointer) into a signed 16-bit short, and advances the offset
in input.
- readSnapshot(InputStream) - Method in class com.netflix.hollow.core.read.engine.HollowBlobReader
-
Initialize the state engine using a snapshot blob from the provided input stream.
- readSnapshot(HollowBlobInput) - Method in class com.netflix.hollow.core.read.engine.HollowBlobReader
-
Initialize the state engine using a snapshot blob from the provided HollowBlobInput.
- readSnapshot(InputStream, HollowFilterConfig) - Method in class com.netflix.hollow.core.read.engine.HollowBlobReader
-
- readSnapshot(InputStream, TypeFilter) - Method in class com.netflix.hollow.core.read.engine.HollowBlobReader
-
Initialize the file engine using a snapshot from the provided input stream.
- readSnapshot(HollowBlobInput, TypeFilter) - Method in class com.netflix.hollow.core.read.engine.HollowBlobReader
-
Initialize the file engine using a snapshot from the provided Hollow Blob Input.
- readSnapshot(HollowBlobInput, OptionalBlobPartInput) - Method in class com.netflix.hollow.core.read.engine.HollowBlobReader
-
- readSnapshot(HollowBlobInput, OptionalBlobPartInput, TypeFilter) - Method in class com.netflix.hollow.core.read.engine.HollowBlobReader
-
- readSnapshot(HollowBlobInput, ArraySegmentRecycler) - Method in class com.netflix.hollow.core.read.engine.HollowTypeReadState
-
- readSnapshot(HollowBlobInput, ArraySegmentRecycler) - Method in class com.netflix.hollow.core.read.engine.list.HollowListTypeReadState
-
- readSnapshot(HollowBlobInput, ArraySegmentRecycler) - Method in class com.netflix.hollow.core.read.engine.map.HollowMapTypeReadState
-
- readSnapshot(HollowBlobInput, ArraySegmentRecycler) - Method in class com.netflix.hollow.core.read.engine.object.HollowObjectTypeReadState
-
- readSnapshot(HollowBlobInput, ArraySegmentRecycler) - Method in class com.netflix.hollow.core.read.engine.set.HollowSetTypeReadState
-
- readString(int, int) - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowObjectDisabledDataAccess
-
- readString(int, int) - Method in interface com.netflix.hollow.core.read.dataaccess.HollowObjectTypeDataAccess
-
- readString(int, int) - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowObjectMissingDataAccess
-
- readString(int, int) - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowObjectProxyDataAccess
-
- readString(int, int) - Method in class com.netflix.hollow.core.read.engine.object.HollowObjectTypeReadState
-
- readString(int, int) - Method in class com.netflix.hollow.tools.history.HollowHistoricalObjectDataAccess
-
- readTypeState - Variable in class com.netflix.hollow.core.write.copy.HollowRecordCopier
-
- readUTF() - Method in class com.netflix.hollow.core.read.HollowBlobInput
-
Reads in a string from this file, encoded using
modified UTF-8
format, and advances the offset in input.
- readVInt(ByteData, long) - Static method in class com.netflix.hollow.core.memory.encoding.VarInt
-
Read a variable length integer from the supplied
ByteData
starting at the specified position.
- readVInt(InputStream) - Static method in class com.netflix.hollow.core.memory.encoding.VarInt
-
Read a variable length integer from the supplied InputStream
- readVInt(HollowBlobInput) - Static method in class com.netflix.hollow.core.memory.encoding.VarInt
-
Read a variable length integer from the supplied HollowBlobInput
- readVLong(ByteData, long) - Static method in class com.netflix.hollow.core.memory.encoding.VarInt
-
Read a variable length long from the supplied
ByteData
starting at the specified position.
- readVLong(InputStream) - Static method in class com.netflix.hollow.core.memory.encoding.VarInt
-
Read a variable length long from the supplied InputStream.
- readVLong(HollowBlobInput) - Static method in class com.netflix.hollow.core.memory.encoding.VarInt
-
Read a variable length long from the supplied HollowBlobInput.
- readVNull(ByteData, long) - Static method in class com.netflix.hollow.core.memory.encoding.VarInt
-
Determine whether or not the value at the specified position in the supplied
ByteData
is
a 'null' variable length integer.
- recalculateFreeOrdinals() - Method in class com.netflix.hollow.core.memory.ByteArrayOrdinalMap
-
- recalculateFreeOrdinals() - Method in class com.netflix.hollow.core.write.HollowTypeWriteState
-
Correct the free ordinal list after using mapOrdinal()
- recordBucketRetrieval() - Method in class com.netflix.hollow.api.sampling.HollowMapSampler
-
- RecordCountVarianceValidator - Class in com.netflix.hollow.api.producer.validation
-
Used to validate if the cardinality change in current cycle is with in the allowed percent for a given typeName.
- RecordCountVarianceValidator(String, float) - Constructor for class com.netflix.hollow.api.producer.validation.RecordCountVarianceValidator
-
- recordCreation(int) - Method in class com.netflix.hollow.api.sampling.HollowObjectCreationSampler
-
- recordFieldAccess(int) - Method in class com.netflix.hollow.api.sampling.HollowObjectSampler
-
- recordGet() - Method in class com.netflix.hollow.api.sampling.HollowListSampler
-
- recordGet() - Method in class com.netflix.hollow.api.sampling.HollowMapSampler
-
- recordGet() - Method in class com.netflix.hollow.api.sampling.HollowSetSampler
-
- recordHashCode(HollowCollectionTypeReadState, int, DiffEqualOrdinalMap.OrdinalIdentityTranslator) - Method in class com.netflix.hollow.tools.diff.exact.mapper.DiffEqualityCollectionMapper
-
- recordHashCode(HollowCollectionTypeReadState, int, DiffEqualOrdinalMap.OrdinalIdentityTranslator) - Method in class com.netflix.hollow.tools.diff.exact.mapper.DiffEqualityOrderedListMapper
-
- recordIterator() - Method in class com.netflix.hollow.api.sampling.HollowListSampler
-
- recordIterator() - Method in class com.netflix.hollow.api.sampling.HollowMapSampler
-
- recordIterator() - Method in class com.netflix.hollow.api.sampling.HollowSetSampler
-
- RecordPrimaryKey - Class in com.netflix.hollow.core.write.objectmapper
-
- RecordPrimaryKey(String, Object[]) - Constructor for class com.netflix.hollow.core.write.objectmapper.RecordPrimaryKey
-
- recordsAreEqual(int, int) - Method in interface com.netflix.hollow.tools.diff.exact.mapper.DiffEqualityTypeMapper.EqualityDeterminer
-
- recordSize() - Method in class com.netflix.hollow.api.sampling.HollowListSampler
-
- recordSize() - Method in class com.netflix.hollow.api.sampling.HollowMapSampler
-
- recordSize() - Method in class com.netflix.hollow.api.sampling.HollowSetSampler
-
- recordStackTrace() - Method in class com.netflix.hollow.api.client.StackTraceRecorder
-
- recordStackTrace(int) - Method in class com.netflix.hollow.api.client.StackTraceRecorder
-
- recordStackTrace() - Method in class com.netflix.hollow.tools.history.HollowHistoricalTypeDataAccess
-
- recreateAndPopulateUsingReadEngine(HollowReadStateEngine) - Static method in class com.netflix.hollow.core.util.HollowWriteStateCreator
-
- recycleByteArray(byte[]) - Method in interface com.netflix.hollow.core.memory.pool.ArraySegmentRecycler
-
- recycleByteArray(byte[]) - Method in class com.netflix.hollow.core.memory.pool.RecyclingRecycler
-
- recycleByteArray(byte[]) - Method in class com.netflix.hollow.core.memory.pool.WastefulRecycler
-
- recycleLongArray(long[]) - Method in interface com.netflix.hollow.core.memory.pool.ArraySegmentRecycler
-
- recycleLongArray(long[]) - Method in class com.netflix.hollow.core.memory.pool.RecyclingRecycler
-
- recycleLongArray(long[]) - Method in class com.netflix.hollow.core.memory.pool.WastefulRecycler
-
- RecyclingRecycler - Class in com.netflix.hollow.core.memory.pool
-
- RecyclingRecycler() - Constructor for class com.netflix.hollow.core.memory.pool.RecyclingRecycler
-
- RecyclingRecycler(int, int) - Constructor for class com.netflix.hollow.core.memory.pool.RecyclingRecycler
-
- referencedTypes - Variable in class com.netflix.hollow.core.schema.HollowObjectSchema
-
- refreshCompleted(long, long, long) - Method in interface com.netflix.hollow.api.client.HollowUpdateListener
-
Deprecated.
Indicates that a refresh completed successfully.
- refreshEndMetricsReporting(ConsumerRefreshMetrics) - Method in interface com.netflix.hollow.api.consumer.metrics.RefreshMetricsReporting
-
Metrics for a refresh (such as duration, status, etc.) are passed to this method at the end of successful and
failed refreshes.
- refreshExecutor - Variable in class com.netflix.hollow.api.consumer.HollowConsumer.Builder
-
- refreshFailed(long, long, long, Throwable) - Method in interface com.netflix.hollow.api.client.HollowUpdateListener
-
Deprecated.
Indicates that a refresh failed with an Exception.
- refreshFailed(long, long, long, Throwable) - Method in class com.netflix.hollow.api.consumer.HollowConsumer.AbstractRefreshListener
-
- refreshFailed(long, long, long, Throwable) - Method in interface com.netflix.hollow.api.consumer.HollowConsumer.RefreshListener
-
Indicates that a refresh failed with an Exception.
- refreshFailed(long, long, long, Throwable) - Method in class com.netflix.hollow.api.consumer.index.HashIndexSelect
-
- refreshFailed(long, long, long, Throwable) - Method in class com.netflix.hollow.api.consumer.index.UniqueKeyIndex
-
- refreshFailed(long, long, long, Throwable) - Method in class com.netflix.hollow.api.consumer.metrics.AbstractRefreshMetricsListener
-
- refreshListener - Variable in class com.netflix.hollow.api.consumer.index.AbstractHollowHashIndex
-
Deprecated.
- refreshListener - Variable in class com.netflix.hollow.api.consumer.index.AbstractHollowUniqueKeyIndex
-
- refreshListeners - Variable in class com.netflix.hollow.api.consumer.HollowConsumer.Builder
-
- refreshLock - Variable in class com.netflix.hollow.api.consumer.HollowConsumer
-
- RefreshMetricsReporting - Interface in com.netflix.hollow.api.consumer.metrics
-
An interface to facilitate reporting of Hollow Consumer refresh metrics.
- refreshStarted(long, long) - Method in interface com.netflix.hollow.api.client.HollowUpdateListener
-
Deprecated.
Indicates that a refresh has begun.
- refreshStarted(long, long) - Method in class com.netflix.hollow.api.consumer.HollowConsumer.AbstractRefreshListener
-
- refreshStarted(long, long) - Method in interface com.netflix.hollow.api.consumer.HollowConsumer.RefreshListener
-
Indicates that a refresh has begun.
- refreshStarted(long, long) - Method in class com.netflix.hollow.api.consumer.index.HashIndexSelect
-
- refreshStarted(long, long) - Method in class com.netflix.hollow.api.consumer.index.UniqueKeyIndex
-
- refreshStarted(long, long) - Method in class com.netflix.hollow.api.consumer.metrics.AbstractRefreshMetricsListener
-
- refreshSuccessful(long, long, long) - Method in class com.netflix.hollow.api.consumer.HollowConsumer.AbstractRefreshListener
-
- refreshSuccessful(long, long, long) - Method in interface com.netflix.hollow.api.consumer.HollowConsumer.RefreshListener
-
Indicates that a refresh completed successfully.
- refreshSuccessful(long, long, long) - Method in class com.netflix.hollow.api.consumer.index.HashIndexSelect
-
- refreshSuccessful(long, long, long) - Method in class com.netflix.hollow.api.consumer.index.UniqueKeyIndex
-
- refreshSuccessful(long, long, long) - Method in class com.netflix.hollow.api.consumer.metrics.AbstractRefreshMetricsListener
-
- relativeBucket(int, int) - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowMapDisabledDataAccess
-
- relativeBucket(int, int) - Method in interface com.netflix.hollow.core.read.dataaccess.HollowMapTypeDataAccess
-
- relativeBucket(int, int) - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowMapMissingDataAccess
-
- relativeBucket(int, int) - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowMapProxyDataAccess
-
- relativeBucket(int, int) - Method in class com.netflix.hollow.core.read.engine.map.HollowMapTypeReadState
-
- relativeBucket(int, int) - Method in class com.netflix.hollow.tools.history.HollowHistoricalMapDataAccess
-
- relativeBucketValue(int, int) - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowSetDisabledDataAccess
-
- relativeBucketValue(int, int) - Method in interface com.netflix.hollow.core.read.dataaccess.HollowSetTypeDataAccess
-
- relativeBucketValue(int, int) - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowSetMissingDataAccess
-
- relativeBucketValue(int, int) - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowSetProxyDataAccess
-
- relativeBucketValue(int, int) - Method in class com.netflix.hollow.core.read.engine.set.HollowSetTypeReadState
-
- relativeBucketValue(int, int) - Method in class com.netflix.hollow.tools.history.HollowHistoricalSetDataAccess
-
- remainingElements() - Method in class com.netflix.hollow.core.memory.encoding.GapEncodedVariableLengthIntegerReader
-
- remap(OrdinalRemapper) - Method in class com.netflix.hollow.tools.history.keyindex.HollowHistoricalStateKeyOrdinalMapping
-
- remap(OrdinalRemapper) - Method in class com.netflix.hollow.tools.history.keyindex.HollowHistoricalStateTypeKeyOrdinalMapping
-
- remapOrdinal(String, int, int) - Method in class com.netflix.hollow.tools.combine.HollowCombinerOrdinalRemapper
-
- remapOrdinal(String, int, int) - Method in class com.netflix.hollow.tools.combine.IdentityOrdinalRemapper
-
- remapOrdinal(String, int, int) - Method in interface com.netflix.hollow.tools.combine.OrdinalRemapper
-
Remap an ordinal.
- remapOrdinal(String, int, int) - Method in class com.netflix.hollow.tools.history.DiffEqualityMappingOrdinalRemapper
-
- remapOrdinal(String, int, int) - Method in class com.netflix.hollow.tools.history.IntMapOrdinalRemapper
-
- remapOrdinal(String, int, int) - Method in class com.netflix.hollow.tools.patch.delta.PartialOrdinalRemapper
-
- remapOrdinal(String, int, int) - Method in class com.netflix.hollow.tools.split.HollowSplitterOrdinalRemapper
-
- remove() - Method in class com.netflix.hollow.core.util.BitSetIterator
-
- REMOVE_REFERENCED_OUTSIDE_CLOSURE - Static variable in interface com.netflix.hollow.tools.traverse.TransitiveSetTraverser.TransitiveSetTraverserAction
-
- removeAllOrdinalsFromThisCycle() - Method in class com.netflix.hollow.core.write.HollowTypeWriteState
-
- removed(HollowTypeReadState, int) - Method in class com.netflix.hollow.tools.history.keyindex.HollowHistoricalStateTypeKeyOrdinalMapping
-
- removed(HollowTypeReadState, int, int) - Method in class com.netflix.hollow.tools.history.keyindex.HollowHistoricalStateTypeKeyOrdinalMapping
-
- removedOrdinal(int) - Method in class com.netflix.hollow.api.objects.provider.HollowObjectCacheProvider
-
- removedOrdinal(int) - Method in class com.netflix.hollow.core.index.HollowHashIndex
-
- removedOrdinal(int) - Method in class com.netflix.hollow.core.index.HollowPrefixIndex
-
- removedOrdinal(int) - Method in class com.netflix.hollow.core.index.HollowPrimaryKeyIndex
-
- removedOrdinal(int) - Method in class com.netflix.hollow.core.index.HollowSparseIntegerSet
-
- removedOrdinal(int) - Method in interface com.netflix.hollow.core.read.engine.HollowTypeStateListener
-
Called once for each record which is removed from the registered type.
- removedOrdinal(int) - Method in class com.netflix.hollow.core.read.engine.PopulatedOrdinalListener
-
- RemovedOrdinalIterator - Class in com.netflix.hollow.core.util
-
A utility to iterate over the ordinals which were removed during the last delta transition applied to a
HollowReadStateEngine
.
- RemovedOrdinalIterator(PopulatedOrdinalListener) - Constructor for class com.netflix.hollow.core.util.RemovedOrdinalIterator
-
- RemovedOrdinalIterator(BitSet, BitSet) - Constructor for class com.netflix.hollow.core.util.RemovedOrdinalIterator
-
- removedOrdinalMappingIterator() - Method in class com.netflix.hollow.tools.history.keyindex.HollowHistoricalStateTypeKeyOrdinalMapping
-
- removedRecords - Variable in class com.netflix.hollow.tools.history.HollowHistoricalTypeDataAccess
-
- removeFromCycleMetadata(String) - Method in class com.netflix.hollow.api.producer.HollowIncrementalProducer
-
Deprecated.
- removeHistoricalStates(int) - Method in class com.netflix.hollow.tools.history.HollowHistory
-
Removes the last n
historical states.
- removeListener(EventListener) - Method in class com.netflix.hollow.api.common.ListenerSupport
-
- removeListener(IncrementalCycleListener) - Method in class com.netflix.hollow.api.producer.HollowIncrementalProducer
-
Deprecated.
- removeListener(HollowProducerListener) - Method in class com.netflix.hollow.api.producer.HollowProducer
-
Removes a listener to this producer.
- removeListener(HollowProducerEventListener) - Method in class com.netflix.hollow.api.producer.HollowProducer
-
Removes a listener to this producer.
- removeListener(HollowTypeStateListener) - Method in class com.netflix.hollow.core.read.engine.HollowTypeReadState
-
- removeOrdinalFromThisCycle(int) - Method in class com.netflix.hollow.core.write.HollowTypeWriteState
-
- removeReferencedOutsideClosure(HollowReadStateEngine, Map<String, BitSet>) - Static method in class com.netflix.hollow.tools.traverse.TransitiveSetTraverser
-
Remove any records from the given selection which are referenced by other records not in the selection.
- removeRefreshListener(HollowConsumer.RefreshListener, HollowConsumer) - Method in class com.netflix.hollow.api.client.HollowClientUpdater
-
- removeRefreshListener(HollowConsumer.RefreshListener) - Method in class com.netflix.hollow.api.consumer.HollowConsumer
-
- requiresMissingFieldTraversal(String) - Method in class com.netflix.hollow.tools.diff.exact.DiffEqualityMapping
-
- requiresTraversalForMissingFields() - Method in class com.netflix.hollow.tools.diff.exact.mapper.DiffEqualityCollectionMapper
-
- requiresTraversalForMissingFields() - Method in class com.netflix.hollow.tools.diff.exact.mapper.DiffEqualityMapMapper
-
- requiresTraversalForMissingFields() - Method in class com.netflix.hollow.tools.diff.exact.mapper.DiffEqualityObjectMapper
-
- requiresTraversalForMissingFields() - Method in class com.netflix.hollow.tools.diff.exact.mapper.DiffEqualityTypeMapper
-
- reservePreviouslyPopulatedOrdinals(BitSet) - Method in class com.netflix.hollow.core.memory.ByteArrayOrdinalMap
-
- reservePrimaryKeyIndexForTypeWithPrimaryKey(boolean) - Method in class com.netflix.hollow.api.codegen.AbstractHollowAPIGeneratorBuilder
-
- reservePrimaryKeyIndexForTypeWithPrimaryKey(boolean) - Method in class com.netflix.hollow.api.codegen.HollowAPIGenerator
-
Use this method to specify to only generate PrimaryKeyIndex for Types that has PrimaryKey defined
Defaults to false to be backwards compatible
- reset() - Method in class com.netflix.hollow.api.sampling.HollowListSampler
-
- reset() - Method in class com.netflix.hollow.api.sampling.HollowMapSampler
-
- reset() - Method in class com.netflix.hollow.api.sampling.HollowObjectCreationSampler
-
- reset() - Method in class com.netflix.hollow.api.sampling.HollowObjectSampler
-
- reset() - Method in interface com.netflix.hollow.api.sampling.HollowSampler
-
- reset() - Method in class com.netflix.hollow.api.sampling.HollowSetSampler
-
- reset() - Method in class com.netflix.hollow.core.memory.ByteDataArray
-
- reset() - Method in class com.netflix.hollow.core.memory.encoding.GapEncodedVariableLengthIntegerReader
-
- reset() - Method in class com.netflix.hollow.core.memory.FreeOrdinalTracker
-
Resets the FreeOrdinalTracker to its initial state.
- reset() - Method in class com.netflix.hollow.core.util.RemovedOrdinalIterator
-
- reset() - Method in class com.netflix.hollow.core.write.HollowListWriteRecord
-
- reset() - Method in class com.netflix.hollow.core.write.HollowMapWriteRecord
-
- reset() - Method in class com.netflix.hollow.core.write.HollowObjectWriteRecord
-
Reset the ByteDataBuffers for each field.
- reset() - Method in class com.netflix.hollow.core.write.HollowSetWriteRecord
-
- reset() - Method in interface com.netflix.hollow.core.write.HollowWriteRecord
-
- reset() - Method in class com.netflix.hollow.core.write.objectmapper.flatrecords.FlatRecordWriter
-
- resetSampling() - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowDisabledDataAccess
-
- resetSampling() - Method in interface com.netflix.hollow.core.read.dataaccess.HollowDataAccess
-
- resetSampling() - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowProxyDataAccess
-
- resetSampling() - Method in class com.netflix.hollow.core.read.engine.HollowReadStateEngine
-
- resetSampling() - Method in class com.netflix.hollow.tools.history.HollowHistoricalStateDataAccess
-
- resetToLastPrepareForNextCycle() - Method in class com.netflix.hollow.core.write.HollowTypeWriteState
-
Resets this write state to empty (i.e.
- resetToLastPrepareForNextCycle() - Method in class com.netflix.hollow.core.write.HollowWriteStateEngine
-
If a state was partially constructed after the last call to prepareForNextCycle(), this call
will remove all of those objects from the state engine and reset to the state it was in at the
last prepareForNextCycle() call.
- resize(int) - Method in class com.netflix.hollow.core.memory.ByteArrayOrdinalMap
-
Resize the ordinal map by increasing its capacity.
- resizeOrdinalMap(int) - Method in class com.netflix.hollow.core.write.HollowTypeWriteState
-
- resolve(List<HollowSchema>) - Method in class com.netflix.hollow.core.read.filter.TypeFilter.Builder
-
- resolve(List<HollowSchema>) - Method in interface com.netflix.hollow.core.read.filter.TypeFilter
-
Resolve this type filter against the provide schema.
- restore(long, HollowConsumer.BlobRetriever) - Method in class com.netflix.hollow.api.producer.HollowIncrementalProducer
-
Deprecated.
- restore(long, HollowConsumer.BlobRetriever) - Method in class com.netflix.hollow.api.producer.HollowProducer.Incremental
-
Restores the data state to a desired version.
- restore(long, HollowConsumer.BlobRetriever) - Method in class com.netflix.hollow.api.producer.HollowProducer
-
Restores the data state to a desired version.
- restoredMap - Variable in class com.netflix.hollow.core.write.HollowTypeWriteState
-
- restoredReadState - Variable in class com.netflix.hollow.core.write.HollowTypeWriteState
-
- restoredSchema - Variable in class com.netflix.hollow.core.write.HollowTypeWriteState
-
- restoreFrom(HollowTypeReadState) - Method in class com.netflix.hollow.core.write.HollowTypeWriteState
-
- restoreFrom(HollowReadStateEngine) - Method in class com.netflix.hollow.core.write.HollowWriteStateEngine
-
- restoreFromLastState() - Method in class com.netflix.hollow.api.producer.HollowIncrementalProducer
-
Deprecated.
Initializes the data model and restores from existing state.
- RestoreListener - Interface in com.netflix.hollow.api.producer.listener
-
A listener of restore events associated with the producer restore stage.
- restoreOrdinal(int, HollowRecordCopier, ByteArrayOrdinalMap, HollowHashableWriteRecord.HashBehavior) - Method in class com.netflix.hollow.core.write.HollowTypeWriteState
-
- retrieveDeltaBlob(long) - Method in interface com.netflix.hollow.api.client.HollowBlobRetriever
-
Deprecated.
- retrieveDeltaBlob(long) - Method in class com.netflix.hollow.api.consumer.fs.HollowFilesystemBlobRetriever
-
- retrieveDeltaBlob(long) - Method in interface com.netflix.hollow.api.consumer.HollowConsumer.BlobRetriever
-
Returns a delta transition which can be applied to the specified version identifier
- retrieveReverseDeltaBlob(long) - Method in interface com.netflix.hollow.api.client.HollowBlobRetriever
-
Deprecated.
- retrieveReverseDeltaBlob(long) - Method in class com.netflix.hollow.api.consumer.fs.HollowFilesystemBlobRetriever
-
- retrieveReverseDeltaBlob(long) - Method in interface com.netflix.hollow.api.consumer.HollowConsumer.BlobRetriever
-
Returns a reverse delta transition which can be applied to the specified version identifier
- retrieveSnapshotBlob(long) - Method in interface com.netflix.hollow.api.client.HollowBlobRetriever
-
Deprecated.
- retrieveSnapshotBlob(long) - Method in class com.netflix.hollow.api.consumer.fs.HollowFilesystemBlobRetriever
-
- retrieveSnapshotBlob(long) - Method in interface com.netflix.hollow.api.consumer.HollowConsumer.BlobRetriever
-
Returns the snapshot for the state with the greatest version identifier which is equal to or less than the desired version
- returnOrdinalToPool(int) - Method in class com.netflix.hollow.core.memory.FreeOrdinalTracker
-
Return an ordinal to the pool after the object to which it was assigned is discarded.
- roundTripDelta(HollowWriteStateEngine, HollowReadStateEngine) - Static method in class com.netflix.hollow.core.util.StateEngineRoundTripper
-
- roundTripSnapshot(HollowWriteStateEngine) - Static method in class com.netflix.hollow.core.util.StateEngineRoundTripper
-
- roundTripSnapshot(HollowWriteStateEngine, HollowReadStateEngine) - Static method in class com.netflix.hollow.core.util.StateEngineRoundTripper
-
- roundTripSnapshot(HollowWriteStateEngine, HollowReadStateEngine, HollowFilterConfig) - Static method in class com.netflix.hollow.core.util.StateEngineRoundTripper
-
- rStateEngine - Variable in class com.netflix.hollow.api.consumer.data.AbstractHollowDataAccessor
-
- runCompactionCycle(HollowCompactor.CompactionConfig) - Method in class com.netflix.hollow.api.producer.HollowProducer
-
Run a compaction cycle, will produce a data state with exactly the same data as currently, but
reorganized so that ordinal holes are filled.
- runCycle() - Method in class com.netflix.hollow.api.producer.HollowIncrementalProducer
-
Deprecated.
Runs a Hollow Cycle, if successful, cleans the mutations map.
- runCycle(HollowProducer.Populator) - Method in class com.netflix.hollow.api.producer.HollowProducer
-
Runs a cycle to populate, publish, and announce a new single data state.
- runIncrementalCycle(HollowProducer.Incremental.IncrementalPopulator) - Method in class com.netflix.hollow.api.producer.HollowProducer.Incremental
-
Runs a cycle to incrementally populate, publish, and announce a new single data state.
- sampler - Variable in class com.netflix.hollow.tools.history.HollowHistoricalTypeDataAccess
-
- SampleResult - Class in com.netflix.hollow.api.sampling
-
- SampleResult(String, long) - Constructor for class com.netflix.hollow.api.sampling.SampleResult
-
- samplingDirector - Variable in class com.netflix.hollow.api.custom.HollowAPI
-
- samplingStatusChanged(boolean) - Method in interface com.netflix.hollow.api.sampling.SamplingStatusListener
-
- SamplingStatusListener - Interface in com.netflix.hollow.api.sampling
-
- schema - Variable in class com.netflix.hollow.api.codegen.api.HollowDataAccessorGenerator
-
- schema - Variable in class com.netflix.hollow.api.codegen.delegate.HollowObjectDelegateGenerator
-
- schema - Variable in class com.netflix.hollow.api.codegen.indexes.HollowUniqueKeyIndexGenerator
-
- schema - Variable in class com.netflix.hollow.core.read.engine.HollowTypeReadState
-
- schema - Variable in class com.netflix.hollow.core.write.HollowTypeWriteState
-
- SchemaNotFoundException - Exception in com.netflix.hollow.api.error
-
An exception thrown when trying to use a schema that does not exist.
- SchemaNotFoundException(String, Collection<String>) - Constructor for exception com.netflix.hollow.api.error.SchemaNotFoundException
-
- scratch() - Method in class com.netflix.hollow.core.write.HollowTypeWriteState
-
Get or create a scratch byte array.
- SearchUtils - Class in com.netflix.hollow.tools.util
-
- SearchUtils() - Constructor for class com.netflix.hollow.tools.util.SearchUtils
-
- seek(long) - Method in class com.netflix.hollow.core.read.HollowBlobInput
-
Sets the file-pointer to the desired offset measured from the beginning of the file by relaying the call to the
underlying RandomAccessFile
.
- SegmentedByteArray - Class in com.netflix.hollow.core.memory
-
A segmented byte array backs the
ByteData
interface with array segments, which potentially come from a pool of reusable memory.
- SegmentedByteArray(ArraySegmentRecycler) - Constructor for class com.netflix.hollow.core.memory.SegmentedByteArray
-
- SegmentedLongArray - Class in com.netflix.hollow.core.memory
-
A segmented long array can grow without allocating successively larger blocks and copying memory.
- SegmentedLongArray(ArraySegmentRecycler, long) - Constructor for class com.netflix.hollow.core.memory.SegmentedLongArray
-
- segments - Variable in class com.netflix.hollow.core.memory.SegmentedLongArray
-
- selectField(String, Class<S>) - Method in class com.netflix.hollow.api.consumer.index.HashIndex.Builder
-
Transitions to build a hash index with result selection.
- selectFieldPath - Variable in class com.netflix.hollow.api.consumer.index.AbstractHollowHashIndex
-
Deprecated.
- serial(byte[]) - Static method in class com.netflix.hollow.core.read.HollowBlobInput
-
- serial(InputStream) - Static method in class com.netflix.hollow.core.read.HollowBlobInput
-
Initialize a serial access Hollow Blob input object from an input stream.
- serializeBitsTo(DataOutputStream) - Method in class com.netflix.hollow.core.memory.ThreadSafeBitSet
-
- set(long, long) - Method in class com.netflix.hollow.core.index.GrowingSegmentedLongArray
-
Set the byte at the given index to the specified value
- set(int) - Method in class com.netflix.hollow.core.index.HollowSparseIntegerSet
-
- set(long, byte) - Method in class com.netflix.hollow.core.memory.SegmentedByteArray
-
Set the byte at the given index to the specified value
- set(long, long) - Method in class com.netflix.hollow.core.memory.SegmentedLongArray
-
Set the long at the given index to the specified value
- set(int) - Method in class com.netflix.hollow.core.memory.ThreadSafeBitSet
-
- set(int, int) - Method in class com.netflix.hollow.core.util.IntList
-
- setAnnouncementDurationMillis(long) - Method in class com.netflix.hollow.api.producer.metrics.AnnouncementMetrics.Builder
-
- setBlobFormatVersion(int) - Method in class com.netflix.hollow.core.HollowBlobHeader
-
- setBoolean(String, boolean) - Method in class com.netflix.hollow.core.write.HollowObjectWriteRecord
-
- setBytes(String, byte[]) - Method in class com.netflix.hollow.core.write.HollowObjectWriteRecord
-
- setClassPostfix(String) - Method in class com.netflix.hollow.api.codegen.CodeGeneratorConfig
-
- setClassPostfix(String) - Method in class com.netflix.hollow.api.codegen.HollowAPIGenerator
-
Use this method to override the default postfix "Hollow" for all generated Hollow object classes.
- setCodeGeneratorConfig(CodeGeneratorConfig) - Method in class com.netflix.hollow.api.codegen.HollowAPIGenerator
-
Set the CodeGeneratorConfig
- setConsecutiveFailures(long) - Method in class com.netflix.hollow.api.consumer.metrics.ConsumerRefreshMetrics.Builder
-
- setConsecutiveFailures(long) - Method in class com.netflix.hollow.api.producer.metrics.CycleMetrics.Builder
-
- setCurrentDataAccess(HollowTypeDataAccess) - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowMapProxyDataAccess
-
- setCurrentDataAccess(HollowTypeDataAccess) - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowObjectProxyDataAccess
-
- setCurrentDataAccess(HollowTypeDataAccess) - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowSetProxyDataAccess
-
- setCurrentDataAccess(HollowTypeDataAccess) - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowTypeProxyDataAccess
-
- setCurrentRandomizedTag(long) - Method in class com.netflix.hollow.core.read.engine.HollowReadStateEngine
-
- setCurrentVersion(long) - Method in class com.netflix.hollow.api.metrics.HollowMetrics
-
- setCycleDurationMillis(long) - Method in class com.netflix.hollow.api.producer.metrics.CycleMetrics.Builder
-
- setCycleStartTimestamp(long) - Method in class com.netflix.hollow.api.consumer.metrics.ConsumerRefreshMetrics.Builder
-
- setDataAccess(HollowDataAccess) - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowProxyDataAccess
-
- setDataSizeBytes(long) - Method in class com.netflix.hollow.api.producer.metrics.AnnouncementMetrics.Builder
-
- setDestinationRandomizedTag(long) - Method in class com.netflix.hollow.core.HollowBlobHeader
-
- setDestinationRandomizedTag(long) - Method in class com.netflix.hollow.core.HollowBlobOptionalPartHeader
-
- setDouble(String, double) - Method in class com.netflix.hollow.core.write.HollowObjectWriteRecord
-
- setDurationMillis(long) - Method in class com.netflix.hollow.api.consumer.metrics.ConsumerRefreshMetrics.Builder
-
- setElementKeyPaths(String...) - Method in class com.netflix.hollow.tools.diff.specific.HollowSpecificDiff
-
Optionally specify paths for which we will match records within an individual type's hierarchy
- setElementMatchPaths(String...) - Method in class com.netflix.hollow.tools.diff.specific.HollowSpecificDiff
-
Set the paths for which we will inspect differences across the two states
- setElementTypeState(HollowTypeReadState) - Method in class com.netflix.hollow.core.schema.HollowListSchema
-
- setElementTypeState(HollowTypeReadState) - Method in class com.netflix.hollow.core.schema.HollowSetSchema
-
- setElementValue(long, int, long) - Method in class com.netflix.hollow.core.memory.encoding.EncodedLongBuffer
-
- setElementValue(long, int, long) - Method in class com.netflix.hollow.core.memory.encoding.FixedLengthElementArray
-
- setElementValue(long, int, long) - Method in interface com.netflix.hollow.core.memory.FixedLengthData
-
- setFieldSpecificSamplingDirector(HollowFilterConfig, HollowSamplingDirector) - Method in class com.netflix.hollow.api.custom.HollowAPI
-
- setFieldSpecificSamplingDirector(HollowFilterConfig, HollowSamplingDirector) - Method in class com.netflix.hollow.api.custom.HollowObjectTypeAPI
-
- setFieldSpecificSamplingDirector(HollowFilterConfig, HollowSamplingDirector) - Method in class com.netflix.hollow.api.custom.HollowTypeAPI
-
- setFieldSpecificSamplingDirector(HollowFilterConfig, HollowSamplingDirector) - Method in class com.netflix.hollow.api.sampling.HollowListSampler
-
- setFieldSpecificSamplingDirector(HollowFilterConfig, HollowSamplingDirector) - Method in class com.netflix.hollow.api.sampling.HollowMapSampler
-
- setFieldSpecificSamplingDirector(HollowFilterConfig, HollowSamplingDirector) - Method in class com.netflix.hollow.api.sampling.HollowObjectCreationSampler
-
- setFieldSpecificSamplingDirector(HollowFilterConfig, HollowSamplingDirector) - Method in class com.netflix.hollow.api.sampling.HollowObjectSampler
-
- setFieldSpecificSamplingDirector(HollowFilterConfig, HollowSamplingDirector) - Method in interface com.netflix.hollow.api.sampling.HollowSampler
-
- setFieldSpecificSamplingDirector(HollowFilterConfig, HollowSamplingDirector) - Method in class com.netflix.hollow.api.sampling.HollowSetSampler
-
- setFieldSpecificSamplingDirector(HollowFilterConfig, HollowSamplingDirector) - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowListDisabledDataAccess
-
- setFieldSpecificSamplingDirector(HollowFilterConfig, HollowSamplingDirector) - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowMapDisabledDataAccess
-
- setFieldSpecificSamplingDirector(HollowFilterConfig, HollowSamplingDirector) - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowObjectDisabledDataAccess
-
- setFieldSpecificSamplingDirector(HollowFilterConfig, HollowSamplingDirector) - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowSetDisabledDataAccess
-
- setFieldSpecificSamplingDirector(HollowFilterConfig, HollowSamplingDirector) - Method in interface com.netflix.hollow.core.read.dataaccess.HollowTypeDataAccess
-
- setFieldSpecificSamplingDirector(HollowFilterConfig, HollowSamplingDirector) - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowListMissingDataAccess
-
- setFieldSpecificSamplingDirector(HollowFilterConfig, HollowSamplingDirector) - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowMapMissingDataAccess
-
- setFieldSpecificSamplingDirector(HollowFilterConfig, HollowSamplingDirector) - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowObjectMissingDataAccess
-
- setFieldSpecificSamplingDirector(HollowFilterConfig, HollowSamplingDirector) - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowSetMissingDataAccess
-
- setFieldSpecificSamplingDirector(HollowFilterConfig, HollowSamplingDirector) - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowTypeProxyDataAccess
-
- setFieldSpecificSamplingDirector(HollowFilterConfig, HollowSamplingDirector) - Method in class com.netflix.hollow.core.read.engine.list.HollowListTypeReadState
-
- setFieldSpecificSamplingDirector(HollowFilterConfig, HollowSamplingDirector) - Method in class com.netflix.hollow.core.read.engine.map.HollowMapTypeReadState
-
- setFieldSpecificSamplingDirector(HollowFilterConfig, HollowSamplingDirector) - Method in class com.netflix.hollow.core.read.engine.object.HollowObjectTypeReadState
-
- setFieldSpecificSamplingDirector(HollowFilterConfig, HollowSamplingDirector) - Method in class com.netflix.hollow.core.read.engine.set.HollowSetTypeReadState
-
- setFieldSpecificSamplingDirector(HollowFilterConfig, HollowSamplingDirector) - Method in class com.netflix.hollow.tools.history.HollowHistoricalTypeDataAccess
-
- setFilter(HollowFilterConfig) - Method in class com.netflix.hollow.api.client.HollowClient
-
Deprecated.
Will apply the filter (i.e.
- setFilter(HollowFilterConfig) - Method in class com.netflix.hollow.api.client.HollowClientUpdater
-
- setFilter(TypeFilter) - Method in class com.netflix.hollow.api.client.HollowClientUpdater
-
- setFloat(String, float) - Method in class com.netflix.hollow.core.write.HollowObjectWriteRecord
-
- setGetterPrefix(String) - Method in class com.netflix.hollow.api.codegen.CodeGeneratorConfig
-
- setGetterPrefix(String) - Method in class com.netflix.hollow.api.codegen.HollowAPIGenerator
-
Use this method to override the default prefix "_" for all getters on all generated Hollow object classes.
- setHeaderTags(Map<String, String>) - Method in class com.netflix.hollow.core.HollowBlobHeader
-
- setHeaderTags(Map<String, String>) - Method in class com.netflix.hollow.core.read.engine.HollowReadStateEngine
-
- setIgnoredTypes(String...) - Method in class com.netflix.hollow.tools.patch.record.HollowStateEngineRecordPatcher
-
- setInt(String, int) - Method in class com.netflix.hollow.core.write.HollowObjectWriteRecord
-
- setIsAnnouncementSuccess(boolean) - Method in class com.netflix.hollow.api.producer.metrics.AnnouncementMetrics.Builder
-
- setIsCycleSuccess(boolean) - Method in class com.netflix.hollow.api.producer.metrics.CycleMetrics.Builder
-
- setIsInitialLoad(boolean) - Method in class com.netflix.hollow.api.consumer.metrics.ConsumerRefreshMetrics.Builder
-
- setIsRefreshSuccess(boolean) - Method in class com.netflix.hollow.api.consumer.metrics.ConsumerRefreshMetrics.Builder
-
- setKeyTypeState(HollowTypeReadState) - Method in class com.netflix.hollow.core.schema.HollowMapSchema
-
- setLastAnnouncementSuccessTimeNano(long) - Method in class com.netflix.hollow.api.producer.metrics.AnnouncementMetrics.Builder
-
- setLastCycleSuccessTimeNano(long) - Method in class com.netflix.hollow.api.producer.metrics.CycleMetrics.Builder
-
- setLatestVersion(long) - Method in class com.netflix.hollow.api.client.HollowAnnouncementWatcher.DefaultWatcher
-
Deprecated.
- setLatestVersion(long) - Method in class com.netflix.hollow.api.client.HollowAnnouncementWatcher
-
Deprecated.
Override this method ONLY if it is legal to explicitly update to a specific version.
- setLong(String, long) - Method in class com.netflix.hollow.core.write.HollowObjectWriteRecord
-
- SetMapKeyHasher - Class in com.netflix.hollow.core.read.engine
-
Hashes POJO keys according to the Set/Map hash key specification.
- SetMapKeyHasher() - Constructor for class com.netflix.hollow.core.read.engine.SetMapKeyHasher
-
- setMaxDeltas(int) - Method in class com.netflix.hollow.api.client.HollowClient
-
Deprecated.
Set the maximum number of deltas which will be followed by this client.
- setMetrics(T) - Method in class com.netflix.hollow.api.metrics.HollowMetricsCollector
-
- setMissingDataHandler(MissingDataHandler) - Method in class com.netflix.hollow.core.read.engine.HollowReadStateEngine
-
- setNextEmptyOrdinal(int) - Method in class com.netflix.hollow.core.memory.FreeOrdinalTracker
-
Specify the next ordinal to return after the reusable pool is exhausted
- setNextState(HollowDataAccess) - Method in class com.netflix.hollow.tools.history.HollowHistoricalStateDataAccess
-
- setNull(String) - Method in class com.netflix.hollow.core.write.HollowObjectWriteRecord
-
- setNumShards(int) - Method in class com.netflix.hollow.core.write.HollowTypeWriteState
-
- setOriginRandomizedTag(long) - Method in class com.netflix.hollow.core.HollowBlobHeader
-
- setOriginRandomizedTag(long) - Method in class com.netflix.hollow.core.HollowBlobOptionalPartHeader
-
- setOverallRefreshType(HollowConsumer.Blob.BlobType) - Method in class com.netflix.hollow.api.consumer.metrics.ConsumerRefreshMetrics.Builder
-
- setPosition(long) - Method in class com.netflix.hollow.core.memory.ByteDataArray
-
- setPrimaryKeys(PrimaryKey...) - Method in class com.netflix.hollow.tools.combine.HollowCombiner
-
When provided, a set of
PrimaryKey
will ensure that no duplicate records are added to the destination state.
- setRecordMatchPaths(String...) - Method in class com.netflix.hollow.tools.diff.specific.HollowSpecificDiff
-
Set the primary key paths which will be used to find matching records across the two states
- setReference(String, int) - Method in class com.netflix.hollow.core.write.HollowObjectWriteRecord
-
- setReferencedTypeState(int, HollowTypeReadState) - Method in class com.netflix.hollow.core.schema.HollowObjectSchema
-
- setRefreshEndTimeNano(long) - Method in class com.netflix.hollow.api.consumer.metrics.ConsumerRefreshMetrics.Builder
-
- setRefreshSuccessAgeMillisOptional(long) - Method in class com.netflix.hollow.api.consumer.metrics.ConsumerRefreshMetrics.Builder
-
- setReservePrimaryKeyIndexForTypeWithPrimaryKey(boolean) - Method in class com.netflix.hollow.api.codegen.CodeGeneratorConfig
-
- setRestrictApiToFieldType(boolean) - Method in class com.netflix.hollow.api.codegen.CodeGeneratorConfig
-
- setRestrictApiToFieldType(boolean) - Method in class com.netflix.hollow.api.codegen.HollowAPIGenerator
-
If setRestrictApiToFieldType is true, api code only generates get<FieldName>
with return type as per schema
Defaults to false to be backwards compatible
- sets() - Method in class com.netflix.hollow.api.objects.generic.GenericHollowList
-
- sets() - Method in class com.netflix.hollow.api.objects.generic.GenericHollowSet
-
- setSamplingDirector(HollowSamplingDirector) - Method in class com.netflix.hollow.api.custom.HollowAPI
-
- setSamplingDirector(HollowSamplingDirector) - Method in class com.netflix.hollow.api.custom.HollowObjectTypeAPI
-
- setSamplingDirector(HollowSamplingDirector) - Method in class com.netflix.hollow.api.custom.HollowTypeAPI
-
- setSamplingDirector(HollowSamplingDirector) - Method in class com.netflix.hollow.api.sampling.HollowListSampler
-
- setSamplingDirector(HollowSamplingDirector) - Method in class com.netflix.hollow.api.sampling.HollowMapSampler
-
- setSamplingDirector(HollowSamplingDirector) - Method in class com.netflix.hollow.api.sampling.HollowObjectCreationSampler
-
- setSamplingDirector(HollowSamplingDirector) - Method in class com.netflix.hollow.api.sampling.HollowObjectSampler
-
- setSamplingDirector(HollowSamplingDirector) - Method in interface com.netflix.hollow.api.sampling.HollowSampler
-
- setSamplingDirector(HollowSamplingDirector) - Method in class com.netflix.hollow.api.sampling.HollowSetSampler
-
- setSamplingDirector(HollowSamplingDirector) - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowListDisabledDataAccess
-
- setSamplingDirector(HollowSamplingDirector) - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowMapDisabledDataAccess
-
- setSamplingDirector(HollowSamplingDirector) - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowObjectDisabledDataAccess
-
- setSamplingDirector(HollowSamplingDirector) - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowSetDisabledDataAccess
-
- setSamplingDirector(HollowSamplingDirector) - Method in interface com.netflix.hollow.core.read.dataaccess.HollowTypeDataAccess
-
- setSamplingDirector(HollowSamplingDirector) - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowListMissingDataAccess
-
- setSamplingDirector(HollowSamplingDirector) - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowMapMissingDataAccess
-
- setSamplingDirector(HollowSamplingDirector) - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowObjectMissingDataAccess
-
- setSamplingDirector(HollowSamplingDirector) - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowSetMissingDataAccess
-
- setSamplingDirector(HollowSamplingDirector) - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowTypeProxyDataAccess
-
- setSamplingDirector(HollowSamplingDirector) - Method in class com.netflix.hollow.core.read.engine.list.HollowListTypeReadState
-
- setSamplingDirector(HollowSamplingDirector) - Method in class com.netflix.hollow.core.read.engine.map.HollowMapTypeReadState
-
- setSamplingDirector(HollowSamplingDirector) - Method in class com.netflix.hollow.core.read.engine.object.HollowObjectTypeReadState
-
- setSamplingDirector(HollowSamplingDirector) - Method in class com.netflix.hollow.core.read.engine.set.HollowSetTypeReadState
-
- setSamplingDirector(HollowSamplingDirector) - Method in class com.netflix.hollow.tools.history.HollowHistoricalTypeDataAccess
-
- setSchemas(List<HollowSchema>) - Method in class com.netflix.hollow.core.HollowBlobHeader
-
- setSchemas(List<HollowSchema>) - Method in class com.netflix.hollow.core.HollowBlobOptionalPartHeader
-
- setStackTraceRecorder(StackTraceRecorder) - Method in class com.netflix.hollow.tools.history.HollowHistoricalStateDataAccess
-
- setString(String, String) - Method in class com.netflix.hollow.core.write.HollowObjectWriteRecord
-
- setTargetMaxTypeShardSize(long) - Method in class com.netflix.hollow.core.write.HollowWriteStateEngine
-
Setting a target max type shard size (specified in bytes) will limit the excess memory pool required to perform delta transitions.
- setTiming(int, int) - Method in class com.netflix.hollow.api.sampling.TimeSliceSamplingDirector
-
- setUpdatePlanDetails(ConsumerRefreshMetrics.UpdatePlanDetails) - Method in class com.netflix.hollow.api.consumer.metrics.ConsumerRefreshMetrics.Builder
-
- setUpdateThread(Thread) - Method in class com.netflix.hollow.api.sampling.DisabledSamplingDirector
-
- setUpdateThread(Thread) - Method in class com.netflix.hollow.api.sampling.HollowListSampler
-
- setUpdateThread(Thread) - Method in class com.netflix.hollow.api.sampling.HollowMapSampler
-
- setUpdateThread(Thread) - Method in class com.netflix.hollow.api.sampling.HollowObjectCreationSampler
-
- setUpdateThread(Thread) - Method in class com.netflix.hollow.api.sampling.HollowObjectSampler
-
- setUpdateThread(Thread) - Method in interface com.netflix.hollow.api.sampling.HollowSampler
-
- setUpdateThread(Thread) - Method in class com.netflix.hollow.api.sampling.HollowSamplingDirector
-
- setUpdateThread(Thread) - Method in class com.netflix.hollow.api.sampling.HollowSetSampler
-
- setUseAggressiveSubstitutions(boolean) - Method in class com.netflix.hollow.api.codegen.CodeGeneratorConfig
-
- setUseAggressiveSubstitutions(boolean) - Method in class com.netflix.hollow.api.codegen.HollowAPIGenerator
-
Use this method to override generated classnames for type names corresponding to any class in the java.lang package.
- setUseBooleanFieldErgonomics(boolean) - Method in class com.netflix.hollow.api.codegen.CodeGeneratorConfig
-
- setUseBooleanFieldErgonomics(boolean) - Method in class com.netflix.hollow.api.codegen.HollowAPIGenerator
-
Use this method to specify to use new boolean field ergonomics for generated API
Defaults to false to be backwards compatible
- setUseHollowPrimitiveTypes(boolean) - Method in class com.netflix.hollow.api.codegen.CodeGeneratorConfig
-
- setUseHollowPrimitiveTypes(boolean) - Method in class com.netflix.hollow.api.codegen.HollowAPIGenerator
-
Use this method to specify to use Hollow Primitive Types instead of generating them per project
Defaults to false to be backwards compatible
- setUsePackageGrouping(boolean) - Method in class com.netflix.hollow.api.codegen.CodeGeneratorConfig
-
- setUsePackageGrouping(boolean) - Method in class com.netflix.hollow.api.codegen.HollowAPIGenerator
-
Use this method to specify to use sub packages in generated code instead of single package
Defaults to false to be backwards compatible
- setUseVerboseToString(boolean) - Method in class com.netflix.hollow.api.codegen.CodeGeneratorConfig
-
- setValueTypeState(HollowTypeReadState) - Method in class com.netflix.hollow.core.schema.HollowMapSchema
-
- Shortcut(String[], String[], HollowObjectSchema.FieldType) - Constructor for class com.netflix.hollow.api.codegen.HollowErgonomicAPIShortcuts.Shortcut
-
- shouldCopy(HollowTypeReadState, int) - Method in interface com.netflix.hollow.tools.combine.HollowCombinerCopyDirector
-
- shouldCopy(HollowTypeReadState, int) - Method in class com.netflix.hollow.tools.combine.HollowCombinerExcludeOrdinalsCopyDirector
-
- shouldCopy(HollowTypeReadState, int) - Method in class com.netflix.hollow.tools.combine.HollowCombinerExcludePrimaryKeysCopyDirector
-
- shouldCopy(HollowTypeReadState, int) - Method in class com.netflix.hollow.tools.combine.HollowCombinerIncludeOrdinalsCopyDirector
-
- shouldCopy(HollowTypeReadState, int) - Method in class com.netflix.hollow.tools.combine.HollowCombinerIncludePrimaryKeysCopyDirector
-
- shouldCopy(HollowTypeReadState, int) - Method in class com.netflix.hollow.tools.patch.record.HollowPatcherCombinerCopyDirector
-
- shouldIndex(int) - Method in interface com.netflix.hollow.core.index.HollowSparseIntegerSet.IndexPredicate
-
- shouldRecord() - Method in class com.netflix.hollow.api.sampling.DisabledSamplingDirector
-
- shouldRecord() - Method in class com.netflix.hollow.api.sampling.EnabledSamplingDirector
-
- shouldRecord() - Method in class com.netflix.hollow.api.sampling.HollowSamplingDirector
-
- shouldRecord() - Method in class com.netflix.hollow.api.sampling.TimeSliceSamplingDirector
-
- SimpleHollowDataset - Class in com.netflix.hollow.core.schema
-
A HollowDataset implementation which only describes a set of schemas comprising a dataset.
- SimpleHollowDataset(Map<String, HollowSchema>) - Constructor for class com.netflix.hollow.core.schema.SimpleHollowDataset
-
- SimpleHollowDataset(List<HollowSchema>) - Constructor for class com.netflix.hollow.core.schema.SimpleHollowDataset
-
- SimultaneousExecutor - Class in com.netflix.hollow.core.util
-
A convenience wrapper around ThreadPoolExecutor.
- SimultaneousExecutor(Class<?>, String) - Constructor for class com.netflix.hollow.core.util.SimultaneousExecutor
-
Creates an executor with a thread per processor.
- SimultaneousExecutor() - Constructor for class com.netflix.hollow.core.util.SimultaneousExecutor
-
- SimultaneousExecutor(double, Class<?>) - Constructor for class com.netflix.hollow.core.util.SimultaneousExecutor
-
Creates an executor with number of threads calculated from the
specified factor.
- SimultaneousExecutor(double) - Constructor for class com.netflix.hollow.core.util.SimultaneousExecutor
-
- SimultaneousExecutor(double, Class<?>, String) - Constructor for class com.netflix.hollow.core.util.SimultaneousExecutor
-
Creates an executor with number of threads calculated from the
specified factor and threads named according to context
and description
.
- SimultaneousExecutor(double, String) - Constructor for class com.netflix.hollow.core.util.SimultaneousExecutor
-
- SimultaneousExecutor(int, Class<?>) - Constructor for class com.netflix.hollow.core.util.SimultaneousExecutor
-
Creates an executor with the specified number of threads and threads named
according to context
.
- SimultaneousExecutor(int) - Constructor for class com.netflix.hollow.core.util.SimultaneousExecutor
-
- SimultaneousExecutor(int, Class<?>, String) - Constructor for class com.netflix.hollow.core.util.SimultaneousExecutor
-
Creates an executor with the specified number of threads and threads named
according to context
and description
.
- SimultaneousExecutor(double, Class<?>, String, int) - Constructor for class com.netflix.hollow.core.util.SimultaneousExecutor
-
Creates an executor with number of threads calculated from the
specified factor and threads named according to context
and description
.
- SimultaneousExecutor(int, Class<?>, String, int) - Constructor for class com.netflix.hollow.core.util.SimultaneousExecutor
-
Creates an executor with the specified number of threads and threads named
according to context
and description
.
- SimultaneousExecutor(int, ThreadFactory) - Constructor for class com.netflix.hollow.core.util.SimultaneousExecutor
-
- SimultaneousExecutor(int, String) - Constructor for class com.netflix.hollow.core.util.SimultaneousExecutor
-
- SingleMatchIterator(int) - Constructor for class com.netflix.hollow.tools.diff.exact.DiffEqualOrdinalMap.SingleMatchIterator
-
- SingleProducerEnforcer - Interface in com.netflix.hollow.api.producer.enforcer
-
- size(int) - Method in class com.netflix.hollow.api.custom.HollowListTypeAPI
-
- size(int) - Method in class com.netflix.hollow.api.custom.HollowMapTypeAPI
-
- size(int) - Method in class com.netflix.hollow.api.custom.HollowSetTypeAPI
-
- size(int) - Method in class com.netflix.hollow.api.objects.delegate.HollowListCachedDelegate
-
- size(int) - Method in interface com.netflix.hollow.api.objects.delegate.HollowListDelegate
-
- size(int) - Method in class com.netflix.hollow.api.objects.delegate.HollowListLookupDelegate
-
- size(int) - Method in class com.netflix.hollow.api.objects.delegate.HollowMapCachedDelegate
-
- size(int) - Method in interface com.netflix.hollow.api.objects.delegate.HollowMapDelegate
-
- size(int) - Method in class com.netflix.hollow.api.objects.delegate.HollowMapLookupDelegate
-
- size(int) - Method in class com.netflix.hollow.api.objects.delegate.HollowSetCachedDelegate
-
- size(int) - Method in interface com.netflix.hollow.api.objects.delegate.HollowSetDelegate
-
- size(int) - Method in class com.netflix.hollow.api.objects.delegate.HollowSetLookupDelegate
-
- size() - Method in class com.netflix.hollow.api.objects.HollowList
-
- size() - Method in class com.netflix.hollow.api.objects.HollowMap
-
- size() - Method in class com.netflix.hollow.api.objects.HollowSet
-
- size() - Method in class com.netflix.hollow.core.index.HollowSparseIntegerSet
-
Estimate the total number of bits used to represent the integer set.
- size() - Method in class com.netflix.hollow.core.memory.EncodedByteBuffer
-
- size() - Method in class com.netflix.hollow.core.memory.SegmentedByteArray
-
- size() - Method in interface com.netflix.hollow.core.memory.VariableLengthData
-
Data size in bytes
- size(int) - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowListDisabledDataAccess
-
- size(int) - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowMapDisabledDataAccess
-
- size(int) - Method in class com.netflix.hollow.core.read.dataaccess.disabled.HollowSetDisabledDataAccess
-
- size(int) - Method in interface com.netflix.hollow.core.read.dataaccess.HollowCollectionTypeDataAccess
-
- size(int) - Method in interface com.netflix.hollow.core.read.dataaccess.HollowMapTypeDataAccess
-
- size(int) - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowListMissingDataAccess
-
- size(int) - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowMapMissingDataAccess
-
- size(int) - Method in class com.netflix.hollow.core.read.dataaccess.missing.HollowSetMissingDataAccess
-
- size(int) - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowListProxyDataAccess
-
- size(int) - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowMapProxyDataAccess
-
- size(int) - Method in class com.netflix.hollow.core.read.dataaccess.proxy.HollowSetProxyDataAccess
-
- size(int) - Method in class com.netflix.hollow.core.read.engine.HollowCollectionTypeReadState
-
- size(int) - Method in class com.netflix.hollow.core.read.engine.list.HollowListTypeReadState
-
- size(int) - Method in class com.netflix.hollow.core.read.engine.map.HollowMapTypeReadState
-
- size(int) - Method in class com.netflix.hollow.core.read.engine.set.HollowSetTypeReadState
-
- size() - Method in class com.netflix.hollow.core.util.HollowRecordCollection
-
- size() - Method in class com.netflix.hollow.core.util.IntList
-
- size() - Method in class com.netflix.hollow.core.util.IntMap
-
- size() - Method in class com.netflix.hollow.core.util.LongList
-
- size(int) - Method in class com.netflix.hollow.tools.history.HollowHistoricalListDataAccess
-
- size(int) - Method in class com.netflix.hollow.tools.history.HollowHistoricalMapDataAccess
-
- size(int) - Method in class com.netflix.hollow.tools.history.HollowHistoricalSetDataAccess
-
- sizeOfVInt(int) - Static method in class com.netflix.hollow.core.memory.encoding.VarInt
-
Determine the size (in bytes) of the specified value when encoded as a variable length integer.
- sizeOfVLong(long) - Static method in class com.netflix.hollow.core.memory.encoding.VarInt
-
Determine the size (in bytes) of the specified value when encoded as a variable length integer.
- skipBytes(long) - Method in class com.netflix.hollow.core.read.HollowBlobInput
-
This method attempts to skip a specified number of bytes and returns the actual number of bytes skipped.
- SMALL_ARRAY_RECYCLER - Static variable in class com.netflix.hollow.core.memory.pool.WastefulRecycler
-
- snapshotApplied(HollowAPI, HollowReadStateEngine, long) - Method in class com.netflix.hollow.api.consumer.HollowConsumer.AbstractRefreshListener
-
- snapshotApplied(HollowAPI, HollowReadStateEngine, long) - Method in interface com.netflix.hollow.api.consumer.HollowConsumer.TransitionAwareRefreshListener
-
This method is called whenever a snapshot is processed.
- snapshotApplied(HollowAPI, HollowReadStateEngine, long) - Method in class com.netflix.hollow.api.consumer.metrics.AbstractRefreshMetricsListener
-
- SnapshotPopulatedOrdinalsReader - Class in com.netflix.hollow.core.read.engine
-
- SnapshotPopulatedOrdinalsReader() - Constructor for class com.netflix.hollow.core.read.engine.SnapshotPopulatedOrdinalsReader
-
- snapshotUpdateOccurred(HollowAPI, HollowReadStateEngine, long) - Method in class com.netflix.hollow.api.consumer.HollowConsumer.AbstractRefreshListener
-
- snapshotUpdateOccurred(HollowAPI, HollowReadStateEngine, long) - Method in interface com.netflix.hollow.api.consumer.HollowConsumer.RefreshListener
-
This method is called when either data was initialized for the first time, or an update occurred across a
discontinuous delta chain (double snapshot).
- snapshotUpdateOccurred(HollowAPI, HollowReadStateEngine, long) - Method in class com.netflix.hollow.api.consumer.index.HashIndexSelect
-
- snapshotUpdateOccurred(HollowAPI, HollowReadStateEngine, long) - Method in class com.netflix.hollow.api.consumer.index.UniqueKeyIndex
-
- snapshotUpdateOccurred(HollowAPI, HollowReadStateEngine, long) - Method in class com.netflix.hollow.api.consumer.metrics.AbstractRefreshMetricsListener
-
- sort() - Method in class com.netflix.hollow.core.memory.FreeOrdinalTracker
-
Ensure that all future ordinals are returned in ascending order.
- sort() - Method in class com.netflix.hollow.core.util.IntList
-
- sort() - Method in class com.netflix.hollow.core.util.LongList
-
- sparseBitSetVolatile - Variable in class com.netflix.hollow.core.index.HollowSparseIntegerSet
-
- SpecifiedConfig(boolean, boolean, long, long) - Constructor for class com.netflix.hollow.api.client.HollowClientMemoryConfig.SpecifiedConfig
-
Deprecated.
- split() - Method in class com.netflix.hollow.tools.split.HollowSplitter
-
- StackTraceNode(String) - Constructor for class com.netflix.hollow.api.client.StackTraceRecorder.StackTraceNode
-
- StackTraceRecorder - Class in com.netflix.hollow.api.client
-
- StackTraceRecorder(int) - Constructor for class com.netflix.hollow.api.client.StackTraceRecorder
-
- StackTraceRecorder.StackTraceNode - Class in com.netflix.hollow.api.client
-
- stagingPath - Variable in class com.netflix.hollow.api.producer.fs.HollowFilesystemBlobStager
-
- StaleHollowReferenceDetector - Class in com.netflix.hollow.api.client
-
Detect stale Hollow references and USAGE of stale hollow references.
- StaleHollowReferenceDetector(HollowConsumer.ObjectLongevityConfig, HollowConsumer.ObjectLongevityDetector) - Constructor for class com.netflix.hollow.api.client.StaleHollowReferenceDetector
-
- staleReferenceExistenceDetected(int) - Method in interface com.netflix.hollow.api.consumer.HollowConsumer.ObjectLongevityDetector
-
Stale reference detection hint.
- staleReferenceUsageDetected(int) - Method in interface com.netflix.hollow.api.consumer.HollowConsumer.ObjectLongevityDetector
-
Stale reference USAGE detection.
- startMonitoring() - Method in class com.netflix.hollow.api.client.StaleHollowReferenceDetector
-
- startSampling() - Method in class com.netflix.hollow.api.sampling.TimeSliceSamplingDirector
-
- stateEngine - Variable in class com.netflix.hollow.core.read.engine.HollowTypeReadState
-
- stateEngine - Variable in class com.netflix.hollow.core.write.HollowTypeWriteState
-
- StateEngineRoundTripper - Class in com.netflix.hollow.core.util
-
- StateEngineRoundTripper() - Constructor for class com.netflix.hollow.core.util.StateEngineRoundTripper
-
- stateListeners - Variable in class com.netflix.hollow.core.read.engine.HollowTypeReadState
-
- Status - Class in com.netflix.hollow.api.producer
-
A status representing success or failure for a particular producer action.
- Status(Status.StatusType, Throwable) - Constructor for class com.netflix.hollow.api.producer.Status
-
- Status.StatusType - Enum in com.netflix.hollow.api.producer
-
The status type.
- stopSampling() - Method in class com.netflix.hollow.api.sampling.TimeSliceSamplingDirector
-
- stream() - Method in class com.netflix.hollow.core.index.HollowHashIndexResult
-
Returns a stream of matching ordinals.
- StringDataAccessor - Class in com.netflix.hollow.core.type.accessor
-
- StringDataAccessor(HollowConsumer) - Constructor for class com.netflix.hollow.core.type.accessor.StringDataAccessor
-
- StringDataAccessor(HollowReadStateEngine, HollowConsumerAPI.StringRetriever) - Constructor for class com.netflix.hollow.core.type.accessor.StringDataAccessor
-
- StringDelegate - Interface in com.netflix.hollow.core.type.delegate
-
- StringDelegateCachedImpl - Class in com.netflix.hollow.core.type.delegate
-
- StringDelegateCachedImpl(StringTypeAPI, int) - Constructor for class com.netflix.hollow.core.type.delegate.StringDelegateCachedImpl
-
- StringDelegateLookupImpl - Class in com.netflix.hollow.core.type.delegate
-
- StringDelegateLookupImpl(StringTypeAPI) - Constructor for class com.netflix.hollow.core.type.delegate.StringDelegateLookupImpl
-
- stringHashCode(String) - Static method in class com.netflix.hollow.core.read.HollowReadFieldUtils
-
- StringHollowFactory - Class in com.netflix.hollow.core.type
-
- StringHollowFactory() - Constructor for class com.netflix.hollow.core.type.StringHollowFactory
-
- stringify(HollowRecord) - Method in class com.netflix.hollow.tools.stringifier.HollowRecordJsonStringifier
-
- stringify(Writer, HollowRecord) - Method in class com.netflix.hollow.tools.stringifier.HollowRecordJsonStringifier
-
- stringify(Writer, Iterable<HollowRecord>) - Method in class com.netflix.hollow.tools.stringifier.HollowRecordJsonStringifier
-
- stringify(HollowDataAccess, String, int) - Method in class com.netflix.hollow.tools.stringifier.HollowRecordJsonStringifier
-
- stringify(Writer, HollowDataAccess, String, int) - Method in class com.netflix.hollow.tools.stringifier.HollowRecordJsonStringifier
-
- stringify(HollowRecord) - Method in class com.netflix.hollow.tools.stringifier.HollowRecordStringifier
-
- stringify(Writer, HollowRecord) - Method in class com.netflix.hollow.tools.stringifier.HollowRecordStringifier
-
- stringify(Writer, Iterable<HollowRecord>) - Method in class com.netflix.hollow.tools.stringifier.HollowRecordStringifier
-
- stringify(HollowDataAccess, String, int) - Method in class com.netflix.hollow.tools.stringifier.HollowRecordStringifier
-
- stringify(Writer, HollowDataAccess, String, int) - Method in class com.netflix.hollow.tools.stringifier.HollowRecordStringifier
-
- stringify(HollowRecord) - Method in interface com.netflix.hollow.tools.stringifier.HollowStringifier
-
Create a String representation of the specified
HollowRecord
.
- stringify(Writer, HollowRecord) - Method in interface com.netflix.hollow.tools.stringifier.HollowStringifier
-
Writes a String representation of the specified
HollowRecord
to the provided Writer.
- stringify(Writer, Iterable<HollowRecord>) - Method in interface com.netflix.hollow.tools.stringifier.HollowStringifier
-
Writes a String representation of the specified collection of
HollowRecord
to the provided Writer.
- stringify(HollowDataAccess, String, int) - Method in interface com.netflix.hollow.tools.stringifier.HollowStringifier
-
Create a String representation of the record in the provided dataset, of the given type, with the specified ordinal.
- stringify(Writer, HollowDataAccess, String, int) - Method in interface com.netflix.hollow.tools.stringifier.HollowStringifier
-
Writes a String representation of the record in the provided dataset, of the given type, with the specified ordinal.
- StringTypeAPI - Class in com.netflix.hollow.core.type
-
- StringTypeAPI(HollowAPI, HollowObjectTypeDataAccess) - Constructor for class com.netflix.hollow.core.type.StringTypeAPI
-
- SUB_PACKAGE_NAME - Static variable in class com.netflix.hollow.api.codegen.api.HollowDataAccessorGenerator
-
- SUB_PACKAGE_NAME - Static variable in class com.netflix.hollow.api.codegen.api.HollowTypeAPIGenerator
-
- SUB_PACKAGE_NAME - Static variable in class com.netflix.hollow.api.codegen.delegate.HollowObjectDelegateGenerator
-
- SUB_PACKAGE_NAME - Static variable in class com.netflix.hollow.api.codegen.HollowAPIClassJavaGenerator
-
- SUB_PACKAGE_NAME - Static variable in class com.netflix.hollow.api.codegen.HollowAPIFactoryJavaGenerator
-
- SUB_PACKAGE_NAME - Static variable in class com.netflix.hollow.api.codegen.indexes.HollowIndexGenerator
-
- SUB_PACKAGE_NAME - Static variable in class com.netflix.hollow.api.codegen.objects.HollowCollectionsGenerator
-
- SUB_PACKAGE_NAME - Static variable in class com.netflix.hollow.api.codegen.objects.HollowFactoryJavaGenerator
-
- SUB_PACKAGE_NAME - Static variable in class com.netflix.hollow.api.codegen.objects.HollowObjectJavaGenerator
-
- subPackageName - Variable in class com.netflix.hollow.api.codegen.HollowConsumerJavaFileGenerator
-
- subscribeToEvents() - Method in class com.netflix.hollow.api.client.HollowAnnouncementWatcher.DefaultWatcher
-
Deprecated.
- subscribeToEvents() - Method in class com.netflix.hollow.api.client.HollowAnnouncementWatcher
-
Deprecated.
If some push announcement mechanism is to be provided by this HollowAnnouncementWatcher, subscribe here.
- subscribeToUpdates(HollowConsumer) - Method in class com.netflix.hollow.api.consumer.fs.HollowFilesystemAnnouncementWatcher
-
- subscribeToUpdates(HollowConsumer) - Method in interface com.netflix.hollow.api.consumer.HollowConsumer.AnnouncementWatcher
-
Implementations of this method should subscribe a HollowConsumer to updates to announced versions.
- substituteInvalidChars(String) - Static method in class com.netflix.hollow.api.codegen.HollowCodeGenerationUtils
-
- supportsFiltering() - Method in enum com.netflix.hollow.core.memory.MemoryMode
-
- swap() - Method in interface com.netflix.hollow.core.memory.pool.ArraySegmentRecycler
-
- swap() - Method in class com.netflix.hollow.core.memory.pool.RecyclingRecycler
-
- swap() - Method in class com.netflix.hollow.core.memory.pool.WastefulRecycler
-
- ValidationResult - Class in com.netflix.hollow.api.producer.validation
-
The result of validation performed by a
validator
.
- ValidationResult.ValidationResultBuilder - Class in com.netflix.hollow.api.producer.validation
-
- ValidationResultType - Enum in com.netflix.hollow.api.producer.validation
-
The type of validation result.
- ValidationStatus - Class in com.netflix.hollow.api.producer.validation
-
The overall status of a sequence of validation results.
- ValidationStatus(List<ValidationResult>) - Constructor for class com.netflix.hollow.api.producer.validation.ValidationStatus
-
Creates a new validation status from a list of validation results.
- ValidationStatusException - Exception in com.netflix.hollow.api.producer.validation
-
A validation status exception holding a validation status.
- ValidationStatusException(ValidationStatus, String) - Constructor for exception com.netflix.hollow.api.producer.validation.ValidationStatusException
-
Creates a validation status exception.
- ValidationStatusListener - Interface in com.netflix.hollow.api.producer.validation
-
A listener of validation status events associated with the producer validation status stage.
- ValidatorListener - Interface in com.netflix.hollow.api.producer.validation
-
- valueOf(String) - Static method in enum com.netflix.hollow.api.codegen.HollowAPIGenerator.GeneratorArguments
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.netflix.hollow.api.codegen.HollowPOJOGenerator.GeneratorArguments
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.netflix.hollow.api.consumer.HollowConsumer.Blob.BlobType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.netflix.hollow.api.producer.HollowProducer.Blob.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.netflix.hollow.api.producer.HollowProducerListener.Status
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.netflix.hollow.api.producer.IncrementalCycleListener.Status
-
Deprecated.
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.netflix.hollow.api.producer.listener.CycleListener.CycleSkipReason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.netflix.hollow.api.producer.Status.StatusType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.netflix.hollow.api.producer.validation.ValidationResultType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.netflix.hollow.core.memory.MemoryMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.netflix.hollow.core.schema.HollowObjectSchema.FieldType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.netflix.hollow.core.schema.HollowSchema.SchemaType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.netflix.hollow.core.write.HollowHashableWriteRecord.HashBehavior
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.netflix.hollow.core.write.objectmapper.NullablePrimitiveBoolean
-
Deprecated.
Returns the enum constant of this type with the specified name.
- values() - Static method in enum com.netflix.hollow.api.codegen.HollowAPIGenerator.GeneratorArguments
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.netflix.hollow.api.codegen.HollowPOJOGenerator.GeneratorArguments
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.netflix.hollow.api.consumer.HollowConsumer.Blob.BlobType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.netflix.hollow.api.producer.HollowProducer.Blob.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.netflix.hollow.api.producer.HollowProducerListener.Status
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.netflix.hollow.api.producer.IncrementalCycleListener.Status
-
Deprecated.
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.netflix.hollow.api.producer.listener.CycleListener.CycleSkipReason
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.netflix.hollow.api.producer.Status.StatusType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.netflix.hollow.api.producer.validation.ValidationResultType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.netflix.hollow.core.memory.MemoryMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.netflix.hollow.core.schema.HollowObjectSchema.FieldType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.netflix.hollow.core.schema.HollowSchema.SchemaType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.netflix.hollow.core.write.HollowHashableWriteRecord.HashBehavior
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.netflix.hollow.core.write.objectmapper.NullablePrimitiveBoolean
-
Deprecated.
Returns an array containing the constants of this enum type, in
the order they are declared.
- VariableLengthData - Interface in com.netflix.hollow.core.memory
-
Conceptually this can be thought of as a single byte array or buffer of undefined length.
- VariableLengthDataFactory - Class in com.netflix.hollow.core.memory
-
- VariableLengthDataFactory() - Constructor for class com.netflix.hollow.core.memory.VariableLengthDataFactory
-
- VarInt - Class in com.netflix.hollow.core.memory.encoding
-
Variable-byte integer encoding and decoding logic
- VarInt() - Constructor for class com.netflix.hollow.core.memory.encoding.VarInt
-
- VERSION_LATEST - Static variable in interface com.netflix.hollow.core.HollowConstants
-
A version of VERSION_LATEST signifies "latest version".
- VERSION_NONE - Static variable in interface com.netflix.hollow.core.HollowConstants
-
A version of VERSION_NONE signifies "no version".
- VersionMinterWithCounter - Class in com.netflix.hollow.api.producer
-
- VersionMinterWithCounter() - Constructor for class com.netflix.hollow.api.producer.VersionMinterWithCounter
-
- Versions - Class in com.netflix.hollow.core.util
-
- VetoableListener - Interface in com.netflix.hollow.api.producer.listener
-
A marker interface to be implemented by a listener which indicates that any runtime exception
thrown by any of the listener's methods will be rethrown rather than, by default, caught and not
thrown.
- VetoableListener.ListenerVetoException - Exception in com.netflix.hollow.api.producer.listener
-
A listener method may throw this exception which will be rethrown rather than caught and not
thrown.