Serialized Form
-
Package com.linkedin.alpini.base.misc
-
Exception com.linkedin.alpini.base.misc.ExceptionWithStatus
class ExceptionWithStatus extends Exception implements Serializable -
Exception com.linkedin.alpini.base.misc.Http2TooManyStreamsException
class Http2TooManyStreamsException extends Exception implements Serializable
-
-
Package com.linkedin.alpini.netty4.handlers
-
Exception com.linkedin.alpini.netty4.handlers.BasicHttpServerCodec.ResponseOutOfSequence
class ResponseOutOfSequence extends io.netty.handler.codec.EncoderException implements Serializable
-
-
Package com.linkedin.alpini.netty4.misc
-
Exception com.linkedin.alpini.netty4.misc.ExceptionWithResponseStatus
class ExceptionWithResponseStatus extends ExceptionWithStatus implements Serializable
-
-
Package com.linkedin.alpini.netty4.ssl
-
Exception com.linkedin.alpini.netty4.ssl.FusedSslHandler.OverflowException
class OverflowException extends IOException implements Serializable -
Exception com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.ConfigHelper.MissingConfigParameterException
class MissingConfigParameterException extends IllegalArgumentException implements Serializable
-
-
Package com.linkedin.alpini.router.api
-
Exception com.linkedin.alpini.router.api.Netty4RouterException
class Netty4RouterException extends RouterException implements Serializable -
Exception com.linkedin.alpini.router.api.RouterException
class RouterException extends ExceptionWithStatus implements Serializable- serialVersionUID:
- 1L
-
Serialized Fields
-
_closeChannel
boolean _closeChannel
-
-
-
Package com.linkedin.avro.fastserde
-
Class com.linkedin.avro.fastserde.FastAvroConcurrentHashMap
class FastAvroConcurrentHashMap extends ConcurrentHashMap<K extends Object,V extends Object> implements Serializable -
Exception com.linkedin.avro.fastserde.FastDeserializerGeneratorException
class FastDeserializerGeneratorException extends RuntimeException implements Serializable- serialVersionUID:
- 1L
-
Exception com.linkedin.avro.fastserde.FastSerdeGeneratorException
class FastSerdeGeneratorException extends RuntimeException implements Serializable -
Exception com.linkedin.avro.fastserde.SchemaAssistantException
class SchemaAssistantException extends RuntimeException implements Serializable
-
-
Package com.linkedin.davinci.client
-
Exception com.linkedin.davinci.client.NonLocalAccessException
class NonLocalAccessException extends VeniceClientException implements Serializable
-
-
Package com.linkedin.davinci.consumer
-
Class com.linkedin.davinci.consumer.VeniceChangeCoordinate
class VeniceChangeCoordinate extends Object implements Externalizable- serialVersionUID:
- 1L
-
Serialization Methods
-
readExternal
- Throws:
IOException
ClassNotFoundException
-
writeExternal
- Throws:
IOException
-
-
Exception com.linkedin.davinci.consumer.VeniceCoordinateOutOfRangeException
class VeniceCoordinateOutOfRangeException extends VeniceException implements Serializable
-
-
Package com.linkedin.davinci.schema.writecompute
-
Exception com.linkedin.davinci.schema.writecompute.WriteComputeSchemaValidator.InvalidWriteComputeException
class InvalidWriteComputeException extends VeniceException implements Serializable
-
-
Package com.linkedin.davinci.store
-
Exception com.linkedin.davinci.store.StorageEngineInitializationException
class StorageEngineInitializationException extends VeniceException implements Serializable- serialVersionUID:
- 1L
-
Exception com.linkedin.davinci.store.StoragePartitionInitializationException
class StoragePartitionInitializationException extends VeniceException implements Serializable- serialVersionUID:
- 1L
-
-
Package com.linkedin.venice.acl
-
Exception com.linkedin.venice.acl.AclException
class AclException extends Exception implements Serializable
-
-
Package com.linkedin.venice.admin.protocol.response
-
Class com.linkedin.venice.admin.protocol.response.AdminResponseRecord
class AdminResponseRecord extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 5761101675693128371L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
class ConsumptionStateSnapshot extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -4602111247704740063L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.admin.protocol.response.ServerConfigSnapshot
class ServerConfigSnapshot extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 6724605933807082490L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
-
Package com.linkedin.venice.beam.consumer
-
Class com.linkedin.venice.beam.consumer.LocalVeniceChangelogConsumerProvider
class LocalVeniceChangelogConsumerProvider extends Object implements Serializable- serialVersionUID:
- 1L
-
Serialized Fields
-
_veniceChangelogConsumerClientFactoryClass
Class<? extends VeniceChangelogConsumerClientFactory> _veniceChangelogConsumerClientFactoryClass
-
-
Class com.linkedin.venice.beam.consumer.PubSubMessageCoder
class PubSubMessageCoder extends org.apache.beam.sdk.coders.StructuredCoder<PubSubMessage<K,ChangeEvent<V>, VeniceChangeCoordinate>> implements Serializable - serialVersionUID:
- 1L
-
Serialized Fields
-
pubSubMessageAvroCoder
org.apache.beam.sdk.extensions.avro.coders.AvroCoder<PubSubMessage<K,
ChangeEvent<V>, VeniceChangeCoordinate>> pubSubMessageAvroCoder
-
-
Class com.linkedin.venice.beam.consumer.VeniceChangelogConsumerIO.Read
class Read extends org.apache.beam.sdk.transforms.PTransform<org.apache.beam.sdk.values.PBegin,org.apache.beam.sdk.values.PCollection<PubSubMessage<K, ChangeEvent<V>, VeniceChangeCoordinate>>> implements Serializable - serialVersionUID:
- 1L
-
Serialized Fields
-
consumerIdSuffix
String consumerIdSuffix
-
localVeniceChangelogConsumerProvider
LocalVeniceChangelogConsumerProvider localVeniceChangelogConsumerProvider
-
partitions
Set<Integer> partitions
-
pollTimeout
org.joda.time.Duration pollTimeout
-
seekTimestamp
long seekTimestamp
-
seekWhence
VeniceChangelogConsumerIO.Read.SeekWhence seekWhence
-
store
String store
-
terminationTimeout
org.joda.time.Duration terminationTimeout
-
-
Class com.linkedin.venice.beam.consumer.VeniceCheckpointMark.Coder
class Coder extends org.apache.beam.sdk.coders.AtomicCoder<VeniceCheckpointMark> implements Serializable- serialVersionUID:
- 1L
-
Serialized Fields
-
_sizeCoder
org.apache.beam.sdk.coders.VarIntCoder _sizeCoder
-
_stringUtf8Coder
org.apache.beam.sdk.coders.StringUtf8Coder _stringUtf8Coder
-
-
Class com.linkedin.venice.beam.consumer.VeniceMessageCoder
class VeniceMessageCoder extends org.apache.beam.sdk.coders.StructuredCoder<org.apache.beam.sdk.values.KV<K,ChangeEvent<V>>> implements Serializable - serialVersionUID:
- 1L
-
-
Package com.linkedin.venice.client.change.capture.protocol
-
Class com.linkedin.venice.client.change.capture.protocol.RecordChangeEvent
class RecordChangeEvent extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 4124505617846281396L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.client.change.capture.protocol.ValueBytes
class ValueBytes extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -7598697125532667570L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
-
Package com.linkedin.venice.client.exceptions
-
Exception com.linkedin.venice.client.exceptions.ServiceDiscoveryException
class ServiceDiscoveryException extends VeniceClientException implements Serializable -
Exception com.linkedin.venice.client.exceptions.VeniceClientException
class VeniceClientException extends VeniceException implements Serializable -
Exception com.linkedin.venice.client.exceptions.VeniceClientHttpException
class VeniceClientHttpException extends VeniceClientException implements Serializable-
Serialized Fields
-
httpStatus
int httpStatus
-
-
-
Exception com.linkedin.venice.client.exceptions.VeniceClientRateExceededException
class VeniceClientRateExceededException extends VeniceClientHttpException implements Serializable
-
-
Package com.linkedin.venice.client.store.schemas
-
Class com.linkedin.venice.client.store.schemas.TestKeyRecord
class TestKeyRecord extends org.apache.avro.specific.SpecificRecordBase implements Externalizable-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
-
Class com.linkedin.venice.client.store.schemas.TestValueRecord
class TestValueRecord extends org.apache.avro.specific.SpecificRecordBase implements Externalizable-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
-
Class com.linkedin.venice.client.store.schemas.TestValueRecordWithMoreFields
class TestValueRecordWithMoreFields extends org.apache.avro.specific.SpecificRecordBase implements Externalizable-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
-
-
Package com.linkedin.venice.client.store.streaming
-
Exception com.linkedin.venice.client.store.streaming.ReadEnvelopeChunkedDeserializer.NotEnoughBytesException
class NotEnoughBytesException extends Exception implements Serializable -
Class com.linkedin.venice.client.store.streaming.VeniceResponseMapImpl
- serialVersionUID:
- 1L
-
-
Package com.linkedin.venice.compression.protocol
-
Class com.linkedin.venice.compression.protocol.FakeCompressingSchema
class FakeCompressingSchema extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 4216097061218321773L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
-
Package com.linkedin.venice.compute.protocol.request
-
Class com.linkedin.venice.compute.protocol.request.ComputeOperation
class ComputeOperation extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 1058520520149010710L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.compute.protocol.request.ComputeRequest
class ComputeRequest extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 5035797444789178955L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.compute.protocol.request.ComputeRequestV1
class ComputeRequestV1 extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -936291794305168013L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.compute.protocol.request.ComputeRequestV2
class ComputeRequestV2 extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -5285908897347269717L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.compute.protocol.request.ComputeRequestV3
class ComputeRequestV3 extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -8486958835725153821L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.compute.protocol.request.ComputeRequestV4
class ComputeRequestV4 extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 4462725568814220827L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.compute.protocol.request.CosineSimilarity
class CosineSimilarity extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -9188492108529286547L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.compute.protocol.request.Count
class Count extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -6654918846552929921L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.compute.protocol.request.DotProduct
class DotProduct extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 2594291556121726255L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.compute.protocol.request.HadamardProduct
class HadamardProduct extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -4373124732804948143L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
-
Package com.linkedin.venice.compute.protocol.request.router
-
Class com.linkedin.venice.compute.protocol.request.router.ComputeRouterRequestKeyV1
class ComputeRouterRequestKeyV1 extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -4281766436911660257L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
-
Package com.linkedin.venice.compute.protocol.response
-
Class com.linkedin.venice.compute.protocol.response.ComputeResponseRecordV1
class ComputeResponseRecordV1 extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -3637528416416965416L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
-
Package com.linkedin.venice.controller.exception
-
Exception com.linkedin.venice.controller.exception.HelixClusterMaintenanceModeException
class HelixClusterMaintenanceModeException extends VeniceException implements Serializable
-
-
Package com.linkedin.venice.controller.kafka.protocol.admin
-
Class com.linkedin.venice.controller.kafka.protocol.admin.AbortMigration
class AbortMigration extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -7742296756716399551L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
class AddVersion extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 257658592603009416L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.controller.kafka.protocol.admin.AdminOperation
class AdminOperation extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -2547633646200222959L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureActiveActiveReplicationForCluster
class ConfigureActiveActiveReplicationForCluster extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 1754070675534614012L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureIncrementalPushForCluster
class ConfigureIncrementalPushForCluster extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 8698705926059766853L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureNativeReplicationForCluster
class ConfigureNativeReplicationForCluster extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -4167226100097952693L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.controller.kafka.protocol.admin.CreateStoragePersona
class CreateStoragePersona extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 6740577141833147284L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.controller.kafka.protocol.admin.DeleteAllVersions
class DeleteAllVersions extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -8072594770977476639L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.controller.kafka.protocol.admin.DeleteOldVersion
class DeleteOldVersion extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 1215291246646587145L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStoragePersona
class DeleteStoragePersona extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 6623011002810696177L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStore
class DeleteStore extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 4591429945995995006L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.controller.kafka.protocol.admin.DeleteUnusedValueSchemas
class DeleteUnusedValueSchemas extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 8603551652339347376L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.controller.kafka.protocol.admin.DerivedSchemaCreation
class DerivedSchemaCreation extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -8878195732301070844L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.controller.kafka.protocol.admin.DisableStoreRead
class DisableStoreRead extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -920977876894325613L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.controller.kafka.protocol.admin.EnableStoreRead
class EnableStoreRead extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -1267789310964944844L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.controller.kafka.protocol.admin.ETLStoreConfigRecord
class ETLStoreConfigRecord extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 2292293113739011415L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.controller.kafka.protocol.admin.HybridStoreConfigRecord
class HybridStoreConfigRecord extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -8729483687668846545L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.controller.kafka.protocol.admin.KillOfflinePushJob
class KillOfflinePushJob extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -9114863684654242414L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.controller.kafka.protocol.admin.MetadataSchemaCreation
class MetadataSchemaCreation extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 5236514718865075092L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.controller.kafka.protocol.admin.MetaSystemStoreAutoCreationValidation
class MetaSystemStoreAutoCreationValidation extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -6259330010023241299L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.controller.kafka.protocol.admin.MigrateStore
class MigrateStore extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -2748439851566632405L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.controller.kafka.protocol.admin.PartitionerConfigRecord
class PartitionerConfigRecord extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -4386728759893759468L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.controller.kafka.protocol.admin.PauseStore
class PauseStore extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 9075160214986248303L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.controller.kafka.protocol.admin.PushStatusSystemStoreAutoCreationValidation
class PushStatusSystemStoreAutoCreationValidation extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -8610863510522801988L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.controller.kafka.protocol.admin.ResumeStore
class ResumeStore extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 6351085370557585029L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.controller.kafka.protocol.admin.RollbackCurrentVersion
class RollbackCurrentVersion extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 7756498062766816034L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.controller.kafka.protocol.admin.RollForwardCurrentVersion
class RollForwardCurrentVersion extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -2587775651125933438L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.controller.kafka.protocol.admin.SchemaMeta
class SchemaMeta extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -693421538839533103L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreCurrentVersion
class SetStoreCurrentVersion extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -6296217683467718491L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreOwner
class SetStoreOwner extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 7820573927951334740L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.controller.kafka.protocol.admin.SetStorePartitionCount
class SetStorePartitionCount extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 594460189223428549L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.controller.kafka.protocol.admin.StoreCreation
class StoreCreation extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -1173065906041385139L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.controller.kafka.protocol.admin.StoreViewConfigRecord
class StoreViewConfigRecord extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 4929852317453019863L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.controller.kafka.protocol.admin.SupersetSchemaCreation
class SupersetSchemaCreation extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -1311029237566773365L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStoragePersona
class UpdateStoragePersona extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -4372262333105325819L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
class UpdateStore extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 7138619503700654313L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.controller.kafka.protocol.admin.ValueSchemaCreation
class ValueSchemaCreation extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -6318199461248512171L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
-
Package com.linkedin.venice.etl
-
Class com.linkedin.venice.etl.VeniceKafkaDecodedRecord
class VeniceKafkaDecodedRecord extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -4589312864521446835L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
-
Package com.linkedin.venice.exceptions
-
Exception com.linkedin.venice.exceptions.ConcurrentBatchPushException
class ConcurrentBatchPushException extends VeniceException implements Serializable -
Exception com.linkedin.venice.exceptions.ConfigurationException
class ConfigurationException extends VeniceException implements Serializable- serialVersionUID:
- 1L
-
Exception com.linkedin.venice.exceptions.DiskLimitExhaustedException
class DiskLimitExhaustedException extends VeniceException implements Serializable -
Exception com.linkedin.venice.exceptions.InvalidVeniceSchemaException
class InvalidVeniceSchemaException extends VeniceException implements Serializable -
Exception com.linkedin.venice.exceptions.KafkaConsumerException
class KafkaConsumerException extends VeniceException implements Serializable- serialVersionUID:
- 1L
-
Exception com.linkedin.venice.exceptions.MemoryLimitExhaustedException
class MemoryLimitExhaustedException extends VeniceException implements Serializable -
Exception com.linkedin.venice.exceptions.MissingKeyInStoreMetadataException
class MissingKeyInStoreMetadataException extends VeniceException implements Serializable -
Exception com.linkedin.venice.exceptions.OperationNotAllowedException
class OperationNotAllowedException extends VeniceHttpException implements Serializable -
Exception com.linkedin.venice.exceptions.PartitionerSchemaMismatchException
class PartitionerSchemaMismatchException extends VeniceException implements Serializable -
Exception com.linkedin.venice.exceptions.PersistenceFailureException
class PersistenceFailureException extends VeniceException implements Serializable- serialVersionUID:
- 1L
-
Exception com.linkedin.venice.exceptions.QuotaExceededException
class QuotaExceededException extends VeniceException implements Serializable -
Exception com.linkedin.venice.exceptions.RecordTooLargeException
class RecordTooLargeException extends VeniceException implements Serializable -
Exception com.linkedin.venice.exceptions.ResourceStillExistsException
class ResourceStillExistsException extends VeniceException implements Serializable -
Exception com.linkedin.venice.exceptions.SchemaDuplicateException
class SchemaDuplicateException extends VeniceException implements Serializable -
Exception com.linkedin.venice.exceptions.SchemaIncompatibilityException
class SchemaIncompatibilityException extends VeniceException implements Serializable -
Exception com.linkedin.venice.exceptions.StorageInitializationException
class StorageInitializationException extends VeniceException implements Serializable- serialVersionUID:
- 1L
-
Exception com.linkedin.venice.exceptions.StoreDisabledException
class StoreDisabledException extends VeniceException implements Serializable -
Exception com.linkedin.venice.exceptions.StoreKeySchemaExistException
class StoreKeySchemaExistException extends VeniceException implements Serializable -
Exception com.linkedin.venice.exceptions.StoreVersionNotFoundException
class StoreVersionNotFoundException extends VeniceNoStoreException implements Serializable -
Exception com.linkedin.venice.exceptions.UndefinedPropertyException
class UndefinedPropertyException extends ConfigurationException implements Serializable- serialVersionUID:
- 1L
-
Exception com.linkedin.venice.exceptions.VeniceAclException
class VeniceAclException extends VeniceException implements Serializable-
Serialized Fields
-
httpErrorCode
int httpErrorCode
-
-
-
Exception com.linkedin.venice.exceptions.VeniceBlobTransferFileNotFoundException
class VeniceBlobTransferFileNotFoundException extends VeniceException implements Serializable -
Exception com.linkedin.venice.exceptions.VeniceChecksumException
class VeniceChecksumException extends VeniceException implements Serializable -
Exception com.linkedin.venice.exceptions.VeniceException
class VeniceException extends RuntimeException implements Serializable- serialVersionUID:
- 1L
-
Serialized Fields
-
errorType
ErrorType errorType
-
-
Exception com.linkedin.venice.exceptions.VeniceHttpException
class VeniceHttpException extends VeniceException implements Serializable-
Serialized Fields
-
statusCode
int statusCode
-
-
-
Exception com.linkedin.venice.exceptions.VeniceInconsistentStoreMetadataException
class VeniceInconsistentStoreMetadataException extends VeniceException implements Serializable -
Exception com.linkedin.venice.exceptions.VeniceIngestionTaskKilledException
class VeniceIngestionTaskKilledException extends VeniceException implements Serializable -
Exception com.linkedin.venice.exceptions.VeniceMessageException
class VeniceMessageException extends VeniceException implements Serializable- serialVersionUID:
- 1L
-
Exception com.linkedin.venice.exceptions.VeniceNoClusterException
class VeniceNoClusterException extends VeniceException implements Serializable-
Serialized Fields
-
clusterName
String clusterName
-
-
-
Exception com.linkedin.venice.exceptions.VeniceNoHelixResourceException
class VeniceNoHelixResourceException extends VeniceRouterException implements Serializable-
Serialized Fields
-
resource
String resource
-
version
int version
-
-
-
Exception com.linkedin.venice.exceptions.VeniceNoStoreException
class VeniceNoStoreException extends VeniceException implements Serializable -
Exception com.linkedin.venice.exceptions.VenicePeersConnectionException
class VenicePeersConnectionException extends VeniceException implements Serializable -
Exception com.linkedin.venice.exceptions.VenicePeersNotFoundException
class VenicePeersNotFoundException extends VeniceException implements Serializable -
Exception com.linkedin.venice.exceptions.VeniceResourceAccessException
class VeniceResourceAccessException extends VeniceException implements Serializable -
Exception com.linkedin.venice.exceptions.VeniceRetriableException
class VeniceRetriableException extends VeniceException implements Serializable -
Exception com.linkedin.venice.exceptions.VeniceRouterException
class VeniceRouterException extends VeniceException implements Serializable -
Exception com.linkedin.venice.exceptions.VeniceStoreAlreadyExistsException
class VeniceStoreAlreadyExistsException extends VeniceException implements Serializable -
Exception com.linkedin.venice.exceptions.VeniceStoreIsMigratedException
class VeniceStoreIsMigratedException extends VeniceException implements Serializable -
Exception com.linkedin.venice.exceptions.VeniceTimeoutException
class VeniceTimeoutException extends VeniceRetriableException implements Serializable -
Exception com.linkedin.venice.exceptions.VeniceUnauthorizedAccessException
class VeniceUnauthorizedAccessException extends VeniceException implements Serializable -
Exception com.linkedin.venice.exceptions.VeniceUnsupportedOperationException
class VeniceUnsupportedOperationException extends VeniceException implements Serializable -
Exception com.linkedin.venice.exceptions.ZkDataAccessException
class ZkDataAccessException extends VeniceException implements Serializable
-
-
Package com.linkedin.venice.exceptions.validation
-
Exception com.linkedin.venice.exceptions.validation.CorruptDataException
class CorruptDataException extends FatalDataValidationException implements Serializable -
Exception com.linkedin.venice.exceptions.validation.DataValidationException
class DataValidationException extends KafkaConsumerException implements Serializable -
Exception com.linkedin.venice.exceptions.validation.DuplicateDataException
class DuplicateDataException extends DataValidationException implements Serializable -
Exception com.linkedin.venice.exceptions.validation.FatalDataValidationException
class FatalDataValidationException extends DataValidationException implements Serializable -
Exception com.linkedin.venice.exceptions.validation.ImproperlyStartedSegmentException
class ImproperlyStartedSegmentException extends MissingDataException implements Serializable -
Exception com.linkedin.venice.exceptions.validation.IncomingDataAfterSegmentEndedException
class IncomingDataAfterSegmentEndedException extends FatalDataValidationException implements Serializable -
Exception com.linkedin.venice.exceptions.validation.MissingDataException
class MissingDataException extends FatalDataValidationException implements Serializable -
Exception com.linkedin.venice.exceptions.validation.UnsupportedMessageTypeException
class UnsupportedMessageTypeException extends CorruptDataException implements Serializable
-
-
Package com.linkedin.venice.hadoop
-
Class com.linkedin.venice.hadoop.PushJobSetting
class PushJobSetting extends Object implements Serializable- serialVersionUID:
- 1L
-
Serialized Fields
-
batchNumBytes
int batchNumBytes
-
childControllerRegionD2ZkHosts
String childControllerRegionD2ZkHosts
-
chunkingEnabled
boolean chunkingEnabled
-
clusterName
String clusterName
-
compressionMetricCollectionEnabled
boolean compressionMetricCollectionEnabled
-
controllerD2ServiceName
String controllerD2ServiceName
-
controllerRetries
int controllerRetries
-
controllerStatusPollRetries
int controllerStatusPollRetries
-
d2Routing
boolean d2Routing
-
dataWriterComputeJobClass
Class<? extends DataWriterComputeJob> dataWriterComputeJobClass
-
deferVersionSwap
boolean deferVersionSwap
-
derivedSchemaId
int derivedSchemaId
-
enablePushJobStatusUpload
boolean enablePushJobStatusUpload
-
enableSSL
boolean enableSSL
-
enableWriteCompute
boolean enableWriteCompute
-
etlValueSchemaTransformation
ETLValueSchemaTransformation etlValueSchemaTransformation
-
extendedSchemaValidityCheckEnabled
boolean extendedSchemaValidityCheckEnabled
-
generatePartialUpdateRecordFromInput
boolean generatePartialUpdateRecordFromInput
-
incrementalPushVersion
String incrementalPushVersion
-
inputDataSchema
org.apache.avro.Schema inputDataSchema
-
inputDataSchemaString
String inputDataSchemaString
-
inputFileDataSizeInBytes
long inputFileDataSizeInBytes
-
inputHasRecords
boolean inputHasRecords
-
inputURI
String inputURI
-
isAvro
boolean isAvro
-
isChunkingEnabled
boolean isChunkingEnabled
-
isDuplicateKeyAllowed
boolean isDuplicateKeyAllowed
-
isIncrementalPush
boolean isIncrementalPush
-
isRmdChunkingEnabled
boolean isRmdChunkingEnabled
-
isSchemaAutoRegisterFromPushJobEnabled
boolean isSchemaAutoRegisterFromPushJobEnabled
-
isSourceETL
boolean isSourceETL
-
isSourceKafka
boolean isSourceKafka
-
isStoreIncrementalPushEnabled
boolean isStoreIncrementalPushEnabled
-
isStoreWriteComputeEnabled
boolean isStoreWriteComputeEnabled
-
isSystemSchemaReaderEnabled
boolean isSystemSchemaReaderEnabled
-
isTargetedRegionPushEnabled
boolean isTargetedRegionPushEnabled
-
isTargetRegionPushWithDeferredSwapEnabled
boolean isTargetRegionPushWithDeferredSwapEnabled
-
isZstdDictCreationRequired
boolean isZstdDictCreationRequired
-
isZstdDictCreationSuccess
boolean isZstdDictCreationSuccess
-
jobExecutionId
String jobExecutionId
-
jobId
String jobId
-
jobServerName
String jobServerName
-
jobStartTimeMs
long jobStartTimeMs
-
jobStatusInUnknownStateTimeoutMs
long jobStatusInUnknownStateTimeoutMs
-
jobTmpDir
String jobTmpDir
-
kafkaInputBrokerUrl
String kafkaInputBrokerUrl
-
kafkaInputBuildNewDictEnabled
boolean kafkaInputBuildNewDictEnabled
-
kafkaInputCombinerEnabled
boolean kafkaInputCombinerEnabled
-
kafkaInputTopic
String kafkaInputTopic
-
kafkaSourceRegion
String kafkaSourceRegion
-
kafkaUrl
String kafkaUrl
-
keyField
String keyField
-
keySchema
org.apache.avro.Schema keySchema
-
keySchemaString
String keySchemaString
-
livenessHeartbeatEnabled
boolean livenessHeartbeatEnabled
-
livenessHeartbeatStoreName
String livenessHeartbeatStoreName
-
materializedViewConfigFlatMap
String materializedViewConfigFlatMap
-
maxRecordSizeBytes
int maxRecordSizeBytes
-
multiRegion
boolean multiRegion
-
parentControllerRegionD2ZkHosts
String parentControllerRegionD2ZkHosts
-
partitionCount
int partitionCount
-
partitionerClass
String partitionerClass
-
partitionerParams
Map<String,
String> partitionerParams -
pollJobStatusIntervalMs
long pollJobStatusIntervalMs
-
pushToSeparateRealtimeTopicEnabled
boolean pushToSeparateRealtimeTopicEnabled
-
repushSourceVersion
int repushSourceVersion
-
repushTTLEnabled
boolean repushTTLEnabled
-
repushTTLStartTimeMs
long repushTTLStartTimeMs
-
rewindTimeInSecondsOverride
long rewindTimeInSecondsOverride
-
rmdChunkingEnabled
boolean rmdChunkingEnabled
-
rmdSchemaDir
String rmdSchemaDir
-
sendControlMessagesDirectly
boolean sendControlMessagesDirectly
-
sharedTmpDir
String sharedTmpDir
-
sourceGridFabric
String sourceGridFabric
-
sourceVersionChunkingEnabled
boolean sourceVersionChunkingEnabled
-
sourceVersionCompressionStrategy
CompressionStrategy sourceVersionCompressionStrategy
-
sslToKafka
boolean sslToKafka
-
storeCompressionStrategy
CompressionStrategy storeCompressionStrategy
-
storeKeySchema
org.apache.avro.Schema storeKeySchema
-
storeName
String storeName
-
storeStorageQuota
long storeStorageQuota
-
suppressEndOfPushMessage
boolean suppressEndOfPushMessage
-
systemSchemaClusterD2ServiceName
String systemSchemaClusterD2ServiceName
-
systemSchemaClusterD2ZKHost
String systemSchemaClusterD2ZKHost
-
targetedRegions
String targetedRegions
-
topic
String topic
-
topicCompressionStrategy
CompressionStrategy topicCompressionStrategy
-
useMapperToBuildDict
boolean useMapperToBuildDict
-
validateRemoteReplayPolicy
BufferReplayPolicy validateRemoteReplayPolicy
-
valueField
String valueField
-
valueSchema
org.apache.avro.Schema valueSchema
-
valueSchemaDir
String valueSchemaDir
-
valueSchemaId
int valueSchemaId
-
valueSchemaString
String valueSchemaString
-
veniceControllerUrl
String veniceControllerUrl
-
version
int version
Version part of the store-version / topic name -
vpjEntryClass
Class<? extends VenicePushJob> vpjEntryClass
-
vsonInputKeySchema
VsonSchema vsonInputKeySchema
-
vsonInputKeySchemaString
String vsonInputKeySchemaString
-
vsonInputValueSchema
VsonSchema vsonInputValueSchema
-
vsonInputValueSchemaString
String vsonInputValueSchemaString
-
-
-
Package com.linkedin.venice.hadoop.exceptions
-
Exception com.linkedin.venice.hadoop.exceptions.VeniceInconsistentSchemaException
class VeniceInconsistentSchemaException extends VeniceException implements Serializable -
Exception com.linkedin.venice.hadoop.exceptions.VeniceSchemaFieldNotFoundException
class VeniceSchemaFieldNotFoundException extends VeniceException implements Serializable-
Serialized Fields
-
fieldName
String fieldName
-
-
-
Exception com.linkedin.venice.hadoop.exceptions.VeniceStoreCreationException
class VeniceStoreCreationException extends VeniceException implements Serializable-
Serialized Fields
-
storeName
String storeName
-
-
-
Exception com.linkedin.venice.hadoop.exceptions.VeniceValidationException
class VeniceValidationException extends VeniceException implements Serializable
-
-
Package com.linkedin.venice.hadoop.input.kafka
-
Class com.linkedin.venice.hadoop.input.kafka.KafkaInputKeyComparator
class KafkaInputKeyComparator extends Object implements Serializable- serialVersionUID:
- 1L
-
Class com.linkedin.venice.hadoop.input.kafka.KafkaInputValueGroupingComparator
class KafkaInputValueGroupingComparator extends KafkaInputKeyComparator implements Serializable- serialVersionUID:
- 1L
-
-
Package com.linkedin.venice.hadoop.input.kafka.avro
-
Class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperKey
class KafkaInputMapperKey extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 5538508172634308478L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
class KafkaInputMapperValue extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 4910625535217701229L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
-
Package com.linkedin.venice.hadoop.output.avro
-
Class com.linkedin.venice.hadoop.output.avro.ValidateSchemaAndBuildDictMapperOutput
class ValidateSchemaAndBuildDictMapperOutput extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -7701303845483798833L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
-
Package com.linkedin.venice.ingestion.control
-
Exception com.linkedin.venice.ingestion.control.DuplicateTopicException
class DuplicateTopicException extends VeniceException implements Serializable
-
-
Package com.linkedin.venice.ingestion.protocol
-
Class com.linkedin.venice.ingestion.protocol.IngestionMetricsReport
class IngestionMetricsReport extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -5878893562914495221L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.ingestion.protocol.IngestionStorageMetadata
class IngestionStorageMetadata extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -5384228618089453893L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.ingestion.protocol.IngestionTaskCommand
class IngestionTaskCommand extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -9176705459973240370L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
class IngestionTaskReport extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -6568008902004261297L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.ingestion.protocol.LoadedStoreUserPartitionMapping
class LoadedStoreUserPartitionMapping extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -1636215181242447934L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.ingestion.protocol.ProcessShutdownCommand
class ProcessShutdownCommand extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 3657549379016066961L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
-
Package com.linkedin.venice.kafka.protocol
-
Class com.linkedin.venice.kafka.protocol.ControlMessage
class ControlMessage extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -8532391313761890626L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.kafka.protocol.Delete
class Delete extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -4107303321109090389L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.kafka.protocol.EndOfIncrementalPush
class EndOfIncrementalPush extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -1445632741261320015L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.kafka.protocol.EndOfPush
class EndOfPush extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 4003892792165692916L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.kafka.protocol.EndOfSegment
class EndOfSegment extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -5920076414965370039L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.kafka.protocol.GUID
class GUID extends org.apache.avro.specific.SpecificFixed implements Externalizable-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
-
Class com.linkedin.venice.kafka.protocol.KafkaMessageEnvelope
class KafkaMessageEnvelope extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -8699300686147399293L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.kafka.protocol.LeaderMetadata
class LeaderMetadata extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 7836207590331712101L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.kafka.protocol.ProducerMetadata
class ProducerMetadata extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 4659296984332473126L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.kafka.protocol.Put
class Put extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -5569758952499376058L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.kafka.protocol.StartOfBufferReplay
class StartOfBufferReplay extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 9010138765721059647L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.kafka.protocol.StartOfIncrementalPush
class StartOfIncrementalPush extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 1337521134574787694L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.kafka.protocol.StartOfPush
class StartOfPush extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -1853024095552748608L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.kafka.protocol.StartOfSegment
class StartOfSegment extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -4246982350298302856L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.kafka.protocol.TopicSwitch
class TopicSwitch extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -5740502939082925729L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.kafka.protocol.Update
class Update extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -406433932799465134L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.kafka.protocol.VersionSwap
class VersionSwap extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -3783906363462869061L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
-
Package com.linkedin.venice.kafka.protocol.state
-
Class com.linkedin.venice.kafka.protocol.state.IncrementalPush
class IncrementalPush extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -2935710582474967181L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.kafka.protocol.state.PartitionState
class PartitionState extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 6737586236421941612L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
class ProducerPartitionState extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 8935563812651224467L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.kafka.protocol.state.StoreVersionState
class StoreVersionState extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 5464674299228142723L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
-
Package com.linkedin.venice.listener
-
Exception com.linkedin.venice.listener.VeniceRequestEarlyTerminationException
class VeniceRequestEarlyTerminationException extends VeniceException implements Serializable-
Serialized Fields
-
storeName
String storeName
-
-
-
-
Package com.linkedin.venice.meta.systemstore.schemas
-
Class com.linkedin.venice.meta.systemstore.schemas.CurrentStoreStates
class CurrentStoreStates extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -5128047373658710394L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.meta.systemstore.schemas.CurrentVersionStates
class CurrentVersionStates extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 629411344499000739L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.meta.systemstore.schemas.ETLStoreConfig
class ETLStoreConfig extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 386615025391165847L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.meta.systemstore.schemas.HybridStoreConfig
class HybridStoreConfig extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 7473400723220428777L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.meta.systemstore.schemas.PartitionerConfig
class PartitionerConfig extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -5265755630831617332L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.meta.systemstore.schemas.StoreAttributes
class StoreAttributes extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 5104876172429937575L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.meta.systemstore.schemas.StoreKeySchemas
class StoreKeySchemas extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -2934197998845380869L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataKey
class StoreMetadataKey extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -1334839667646732363L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataValue
class StoreMetadataValue extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -9135862411773726654L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
class StoreProperties extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -1802296258588938995L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.meta.systemstore.schemas.StoreValueSchemas
class StoreValueSchemas extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -5679399156358118730L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
class StoreVersionState extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -5195737296664976852L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.meta.systemstore.schemas.TargetVersionStates
class TargetVersionStates extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 9193702374697293247L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
-
Package com.linkedin.venice.metadata.response
-
Class com.linkedin.venice.metadata.response.MetadataResponseRecord
class MetadataResponseRecord extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 2383786821899158742L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.metadata.response.StorePropertiesResponseRecord
class StorePropertiesResponseRecord extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 3006913302127726268L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.metadata.response.VersionProperties
class VersionProperties extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -1824849756083326443L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
-
Package com.linkedin.venice.participant.protocol
-
Class com.linkedin.venice.participant.protocol.KillPushJob
class KillPushJob extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -4063173186862784375L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.participant.protocol.ParticipantMessageKey
class ParticipantMessageKey extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -6485568257730176435L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.participant.protocol.ParticipantMessageValue
class ParticipantMessageValue extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 4874599879507206794L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
-
Package com.linkedin.venice.protocols
-
Class com.linkedin.venice.protocols.VeniceClientRequest
class VeniceClientRequest extends com.google.protobuf.GeneratedMessageV3 implements Serializable- serialVersionUID:
- 0L
-
Serialized Fields
-
isBatchRequest_
boolean isBatchRequest_
-
isRetryRequest_
boolean isRetryRequest_
-
isStreamingRequest_
boolean isStreamingRequest_
-
keyBytes_
com.google.protobuf.ByteString keyBytes_
-
keyString_
Object keyString_
-
memoizedIsInitialized
byte memoizedIsInitialized
-
method_
Object method_
-
partition_
int partition_
-
resourceName_
Object resourceName_
-
-
Class com.linkedin.venice.protocols.VeniceServerResponse
class VeniceServerResponse extends com.google.protobuf.GeneratedMessageV3 implements Serializable- serialVersionUID:
- 0L
-
Serialized Fields
-
compressionStrategy_
int compressionStrategy_
-
data_
com.google.protobuf.ByteString data_
-
errorCode_
int errorCode_
-
errorMessage_
Object errorMessage_
-
isStreamingResponse_
boolean isStreamingResponse_
-
memoizedIsInitialized
byte memoizedIsInitialized
-
responseRCU_
int responseRCU_
-
schemaId_
int schemaId_
-
-
-
Package com.linkedin.venice.protocols.controller
-
Class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcRequest
class AdminCommandExecutionStatusGrpcRequest extends com.google.protobuf.GeneratedMessageV3 implements Serializable- serialVersionUID:
- 0L
-
Serialized Fields
-
adminCommandExecutionId_
long adminCommandExecutionId_
-
clusterName_
Object clusterName_
-
memoizedIsInitialized
byte memoizedIsInitialized
-
-
Class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse
class AdminCommandExecutionStatusGrpcResponse extends com.google.protobuf.GeneratedMessageV3 implements Serializable- serialVersionUID:
- 0L
-
Serialized Fields
-
Class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata
class AdminTopicGrpcMetadata extends com.google.protobuf.GeneratedMessageV3 implements Serializable- serialVersionUID:
- 0L
-
Class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcRequest
class AdminTopicMetadataGrpcRequest extends com.google.protobuf.GeneratedMessageV3 implements Serializable- serialVersionUID:
- 0L
-
Class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcResponse
class AdminTopicMetadataGrpcResponse extends com.google.protobuf.GeneratedMessageV3 implements Serializable- serialVersionUID:
- 0L
-
Serialized Fields
-
memoizedIsInitialized
byte memoizedIsInitialized
-
metadata_
AdminTopicGrpcMetadata metadata_
-
-
Class com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo
class ClusterStoreGrpcInfo extends com.google.protobuf.GeneratedMessageV3 implements Serializable- serialVersionUID:
- 0L
-
Class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest
class CreateStoreGrpcRequest extends com.google.protobuf.GeneratedMessageV3 implements Serializable- serialVersionUID:
- 0L
-
Serialized Fields
-
accessPermission_
Object accessPermission_
-
bitField0_
int bitField0_
-
isSystemStore_
boolean isSystemStore_
-
keySchema_
Object keySchema_
-
memoizedIsInitialized
byte memoizedIsInitialized
-
owner_
Object owner_
-
storeInfo_
ClusterStoreGrpcInfo storeInfo_
-
valueSchema_
Object valueSchema_
-
-
Class com.linkedin.venice.protocols.controller.CreateStoreGrpcResponse
class CreateStoreGrpcResponse extends com.google.protobuf.GeneratedMessageV3 implements Serializable- serialVersionUID:
- 0L
-
Serialized Fields
-
memoizedIsInitialized
byte memoizedIsInitialized
-
owner_
Object owner_
-
storeInfo_
ClusterStoreGrpcInfo storeInfo_
-
-
Class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcRequest
class DeleteAclForStoreGrpcRequest extends com.google.protobuf.GeneratedMessageV3 implements Serializable- serialVersionUID:
- 0L
-
Serialized Fields
-
memoizedIsInitialized
byte memoizedIsInitialized
-
storeInfo_
ClusterStoreGrpcInfo storeInfo_
-
-
Class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcResponse
class DeleteAclForStoreGrpcResponse extends com.google.protobuf.GeneratedMessageV3 implements Serializable- serialVersionUID:
- 0L
-
Serialized Fields
-
memoizedIsInitialized
byte memoizedIsInitialized
-
storeInfo_
ClusterStoreGrpcInfo storeInfo_
-
-
Class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcRequest
class DiscoverClusterGrpcRequest extends com.google.protobuf.GeneratedMessageV3 implements Serializable- serialVersionUID:
- 0L
-
Serialized Fields
-
memoizedIsInitialized
byte memoizedIsInitialized
-
storeName_
Object storeName_
-
-
Class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse
class DiscoverClusterGrpcResponse extends com.google.protobuf.GeneratedMessageV3 implements Serializable- serialVersionUID:
- 0L
-
Serialized Fields
-
Class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcRequest
class GetAclForStoreGrpcRequest extends com.google.protobuf.GeneratedMessageV3 implements Serializable- serialVersionUID:
- 0L
-
Serialized Fields
-
memoizedIsInitialized
byte memoizedIsInitialized
-
storeInfo_
ClusterStoreGrpcInfo storeInfo_
-
-
Class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcResponse
class GetAclForStoreGrpcResponse extends com.google.protobuf.GeneratedMessageV3 implements Serializable- serialVersionUID:
- 0L
-
Serialized Fields
-
accessPermissions_
Object accessPermissions_
-
memoizedIsInitialized
byte memoizedIsInitialized
-
storeInfo_
ClusterStoreGrpcInfo storeInfo_
-
-
Class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcRequest
class LastSuccessfulAdminCommandExecutionGrpcRequest extends com.google.protobuf.GeneratedMessageV3 implements Serializable- serialVersionUID:
- 0L
-
Serialized Fields
-
clusterName_
Object clusterName_
-
memoizedIsInitialized
byte memoizedIsInitialized
-
-
Class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcResponse
class LastSuccessfulAdminCommandExecutionGrpcResponse extends com.google.protobuf.GeneratedMessageV3 implements Serializable- serialVersionUID:
- 0L
-
Serialized Fields
-
clusterName_
Object clusterName_
-
lastSuccessfulAdminCommandExecutionId_
long lastSuccessfulAdminCommandExecutionId_
-
memoizedIsInitialized
byte memoizedIsInitialized
-
-
Class com.linkedin.venice.protocols.controller.LeaderControllerGrpcRequest
class LeaderControllerGrpcRequest extends com.google.protobuf.GeneratedMessageV3 implements Serializable- serialVersionUID:
- 0L
-
Serialized Fields
-
clusterName_
Object clusterName_
-
memoizedIsInitialized
byte memoizedIsInitialized
-
-
Class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse
class LeaderControllerGrpcResponse extends com.google.protobuf.GeneratedMessageV3 implements Serializable- serialVersionUID:
- 0L
-
Class com.linkedin.venice.protocols.controller.ResourceCleanupCheckGrpcResponse
class ResourceCleanupCheckGrpcResponse extends com.google.protobuf.GeneratedMessageV3 implements Serializable- serialVersionUID:
- 0L
-
Serialized Fields
-
bitField0_
int bitField0_
-
description_
Object description_
-
hasLingeringResources_
boolean hasLingeringResources_
-
memoizedIsInitialized
byte memoizedIsInitialized
-
storeInfo_
ClusterStoreGrpcInfo storeInfo_
-
-
Class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcRequest
class UpdateAclForStoreGrpcRequest extends com.google.protobuf.GeneratedMessageV3 implements Serializable- serialVersionUID:
- 0L
-
Serialized Fields
-
accessPermissions_
Object accessPermissions_
-
memoizedIsInitialized
byte memoizedIsInitialized
-
storeInfo_
ClusterStoreGrpcInfo storeInfo_
-
-
Class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcResponse
class UpdateAclForStoreGrpcResponse extends com.google.protobuf.GeneratedMessageV3 implements Serializable- serialVersionUID:
- 0L
-
Serialized Fields
-
memoizedIsInitialized
byte memoizedIsInitialized
-
storeInfo_
ClusterStoreGrpcInfo storeInfo_
-
-
Class com.linkedin.venice.protocols.controller.UpdateAdminTopicMetadataGrpcRequest
class UpdateAdminTopicMetadataGrpcRequest extends com.google.protobuf.GeneratedMessageV3 implements Serializable- serialVersionUID:
- 0L
-
Serialized Fields
-
memoizedIsInitialized
byte memoizedIsInitialized
-
metadata_
AdminTopicGrpcMetadata metadata_
-
-
Class com.linkedin.venice.protocols.controller.UpdateAdminTopicMetadataGrpcResponse
class UpdateAdminTopicMetadataGrpcResponse extends com.google.protobuf.GeneratedMessageV3 implements Serializable- serialVersionUID:
- 0L
-
Class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo
class VeniceControllerGrpcErrorInfo extends com.google.protobuf.GeneratedMessageV3 implements Serializable- serialVersionUID:
- 0L
-
-
Package com.linkedin.venice.pubsub.api
-
Class com.linkedin.venice.pubsub.api.PubSubPositionWireFormat
class PubSubPositionWireFormat extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -1143464011218848508L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
-
Package com.linkedin.venice.pubsub.api.exceptions
-
Exception com.linkedin.venice.pubsub.api.exceptions.PubSubClientException
class PubSubClientException extends VeniceException implements Serializable -
Exception com.linkedin.venice.pubsub.api.exceptions.PubSubClientRetriableException
class PubSubClientRetriableException extends VeniceRetriableException implements Serializable -
Exception com.linkedin.venice.pubsub.api.exceptions.PubSubOpTimeoutException
class PubSubOpTimeoutException extends PubSubClientRetriableException implements Serializable -
Exception com.linkedin.venice.pubsub.api.exceptions.PubSubTopicAuthorizationException
class PubSubTopicAuthorizationException extends PubSubClientException implements Serializable -
Exception com.linkedin.venice.pubsub.api.exceptions.PubSubTopicDoesNotExistException
class PubSubTopicDoesNotExistException extends PubSubClientRetriableException implements Serializable -
Exception com.linkedin.venice.pubsub.api.exceptions.PubSubTopicExistsException
class PubSubTopicExistsException extends PubSubClientException implements Serializable -
Exception com.linkedin.venice.pubsub.api.exceptions.PubSubUnsubscribedTopicPartitionException
class PubSubUnsubscribedTopicPartitionException extends PubSubClientException implements Serializable
-
-
Package com.linkedin.venice.pulsar.sink
-
Class com.linkedin.venice.pulsar.sink.VenicePulsarSinkConfig
class VenicePulsarSinkConfig extends Object implements Serializable- serialVersionUID:
- 1L
-
Serialized Fields
-
flushIntervalMs
long flushIntervalMs
-
kafkaSaslConfig
String kafkaSaslConfig
-
kafkaSaslMechanism
String kafkaSaslMechanism
-
kafkaSecurityProtocol
String kafkaSecurityProtocol
-
maxNumberUnflushedRecords
int maxNumberUnflushedRecords
-
storeName
String storeName
-
veniceDiscoveryUrl
String veniceDiscoveryUrl
-
veniceRouterUrl
String veniceRouterUrl
-
writerConfig
Map<String,
String> writerConfig
-
-
-
Package com.linkedin.venice.pushstatus
-
Class com.linkedin.venice.pushstatus.PushStatusKey
class PushStatusKey extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -1077248654244901549L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.pushstatus.PushStatusValue
class PushStatusValue extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -1161703101625203416L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
-
Package com.linkedin.venice.read.protocol.request.router
-
Class com.linkedin.venice.read.protocol.request.router.MultiGetRouterRequestKeyV1
class MultiGetRouterRequestKeyV1 extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -4292765688184143483L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
-
Package com.linkedin.venice.read.protocol.response
-
Class com.linkedin.venice.read.protocol.response.MultiGetResponseRecordV1
class MultiGetResponseRecordV1 extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -1339531883776153861L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
-
Package com.linkedin.venice.read.protocol.response.streaming
-
Package com.linkedin.venice.router.exception
-
Exception com.linkedin.venice.router.exception.VeniceKeyCountLimitException
class VeniceKeyCountLimitException extends VeniceException implements Serializable-
Serialized Fields
-
requestKeyCount
int requestKeyCount
-
requestType
RequestType requestType
-
storeName
String storeName
-
-
-
-
Package com.linkedin.venice.samza
-
Class com.linkedin.venice.samza.VeniceSystemFactory
class VeniceSystemFactory extends Object implements Serializable- serialVersionUID:
- 1L
-
Serialized Fields
-
systemProducerStatues
Map<org.apache.samza.system.SystemProducer,
Pair<Boolean, Boolean>> systemProducerStatues Key: VeniceSystemProducer instance; Value: a pair of boolean: <isActive, isStreamReprocessingJobSucceeded> For each SystemProducer created through this factory, keep track of its status in the below Map.RouterBasedPushMonitor
will update the status of the SystemProducer.
-
-
-
Package com.linkedin.venice.schema.vson
-
Class com.linkedin.venice.schema.vson.VsonAvroDatumReader.DeepEqualsArrayList
- serialVersionUID:
- 1L
-
Class com.linkedin.venice.schema.vson.VsonAvroDatumReader.DeepEqualsHashMap
- serialVersionUID:
- 1L
-
Class com.linkedin.venice.schema.vson.VsonSchema
class VsonSchema extends Object implements Serializable- serialVersionUID:
- 1L
-
Serialized Fields
-
type
Object type
Deprecated.
-
-
-
Package com.linkedin.venice.security
-
Exception com.linkedin.venice.security.SSLConfig.ConfigHelper.MissingConfigParameterException
class MissingConfigParameterException extends IllegalArgumentException implements Serializable
-
-
Package com.linkedin.venice.serializer
-
Exception com.linkedin.venice.serializer.VeniceSerializationException
class VeniceSerializationException extends VeniceException implements Serializable -
Exception com.linkedin.venice.serializer.VsonSerializationException
class VsonSerializationException extends VeniceException implements Serializable
-
-
Package com.linkedin.venice.spark.datawriter.partition
-
Class com.linkedin.venice.spark.datawriter.partition.PartitionSorter
class PartitionSorter extends Object implements Serializable- serialVersionUID:
- 1L
-
Class com.linkedin.venice.spark.datawriter.partition.VeniceSparkPartitioner
class VeniceSparkPartitioner extends org.apache.spark.Partitioner implements Serializable- serialVersionUID:
- 1L
-
Serialized Fields
-
broadcastProperties
org.apache.spark.broadcast.Broadcast<Properties> broadcastProperties
-
numPartitions
int numPartitions
-
-
-
Package com.linkedin.venice.spark.datawriter.recordprocessor
-
Class com.linkedin.venice.spark.datawriter.recordprocessor.SparkInputRecordProcessorFactory
class SparkInputRecordProcessorFactory extends Object implements Serializable- serialVersionUID:
- 1L
-
Serialized Fields
-
accumulators
DataWriterAccumulators accumulators
-
jobProps
org.apache.spark.broadcast.Broadcast<Properties> jobProps
-
-
-
Package com.linkedin.venice.spark.datawriter.task
-
Class com.linkedin.venice.spark.datawriter.task.DataWriterAccumulators
class DataWriterAccumulators extends Object implements Serializable- serialVersionUID:
- 1L
-
Serialized Fields
-
compressedValueSizeCounter
org.apache.spark.util.LongAccumulator compressedValueSizeCounter
-
duplicateKeyWithDistinctValueCounter
org.apache.spark.util.LongAccumulator duplicateKeyWithDistinctValueCounter
-
duplicateKeyWithIdenticalValueCounter
org.apache.spark.util.LongAccumulator duplicateKeyWithIdenticalValueCounter
-
emptyRecordCounter
org.apache.spark.util.LongAccumulator emptyRecordCounter
-
gzipCompressedValueSizeCounter
org.apache.spark.util.LongAccumulator gzipCompressedValueSizeCounter
-
outputRecordCounter
org.apache.spark.util.LongAccumulator outputRecordCounter
-
partitionWriterCloseCounter
org.apache.spark.util.LongAccumulator partitionWriterCloseCounter
-
recordTooLargeFailureCounter
org.apache.spark.util.LongAccumulator recordTooLargeFailureCounter
-
repushTtlFilteredRecordCounter
org.apache.spark.util.LongAccumulator repushTtlFilteredRecordCounter
-
sprayAllPartitionsTriggeredCount
org.apache.spark.util.LongAccumulator sprayAllPartitionsTriggeredCount
-
totalKeySizeCounter
org.apache.spark.util.LongAccumulator totalKeySizeCounter
-
uncompressedValueSizeCounter
org.apache.spark.util.LongAccumulator uncompressedValueSizeCounter
-
writeAclAuthorizationFailureCounter
org.apache.spark.util.LongAccumulator writeAclAuthorizationFailureCounter
-
zstdCompressedValueSizeCounter
org.apache.spark.util.LongAccumulator zstdCompressedValueSizeCounter
-
-
-
Package com.linkedin.venice.spark.datawriter.writer
-
Class com.linkedin.venice.spark.datawriter.writer.SparkPartitionWriterFactory
class SparkPartitionWriterFactory extends Object implements Serializable- serialVersionUID:
- 1L
-
Serialized Fields
-
accumulators
DataWriterAccumulators accumulators
-
jobProps
org.apache.spark.broadcast.Broadcast<Properties> jobProps
-
-
-
Package com.linkedin.venice.spark.input.hdfs
-
Class com.linkedin.venice.spark.input.hdfs.VeniceHdfsInputPartition
class VeniceHdfsInputPartition extends Object implements Serializable- serialVersionUID:
- 1L
-
Serialized Fields
-
filePathURI
URI filePathURI
-
-
Class com.linkedin.venice.spark.input.hdfs.VeniceHdfsInputPartitionReaderFactory
class VeniceHdfsInputPartitionReaderFactory extends Object implements Serializable- serialVersionUID:
- 1L
-
Serialized Fields
-
jobConfig
VeniceProperties jobConfig
-
-
-
Package com.linkedin.venice.status.protocol
-
Class com.linkedin.venice.status.protocol.BatchJobHeartbeatKey
class BatchJobHeartbeatKey extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 3641239702220214112L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.status.protocol.BatchJobHeartbeatValue
class BatchJobHeartbeatValue extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 3964758583432955202L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.status.protocol.PushJobDetails
class PushJobDetails extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 8493479868717346395L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.status.protocol.PushJobDetailsStatusTuple
class PushJobDetailsStatusTuple extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -8748825183356649810L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.status.protocol.PushJobStatusRecordKey
class PushJobStatusRecordKey extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -8756503431514842211L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
-
Package com.linkedin.venice.storage.protocol
-
Class com.linkedin.venice.storage.protocol.ChunkedKeySuffix
class ChunkedKeySuffix extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 556587138401303468L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.storage.protocol.ChunkedValueManifest
class ChunkedValueManifest extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 8111551772284562083L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.storage.protocol.ChunkId
class ChunkId extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 4013130109663765556L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
-
Package com.linkedin.venice.store.exception
-
Exception com.linkedin.venice.store.exception.InvalidDatabaseNameException
class InvalidDatabaseNameException extends VeniceException implements Serializable
-
-
Package com.linkedin.venice.systemstore.schemas
-
Class com.linkedin.venice.systemstore.schemas.DataRecoveryConfig
class DataRecoveryConfig extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -8635018859291271327L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.systemstore.schemas.StoreClusterConfig
class StoreClusterConfig extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 8366194660284966595L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.systemstore.schemas.StoreETLConfig
class StoreETLConfig extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -5446769225069350281L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.systemstore.schemas.StoreHybridConfig
class StoreHybridConfig extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -5013815664427103704L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.systemstore.schemas.StoreKeySchemas
class StoreKeySchemas extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -1510578967185446890L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.systemstore.schemas.StoreMetaKey
class StoreMetaKey extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -5266781807689106608L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.systemstore.schemas.StoreMetaValue
class StoreMetaValue extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 8125627235713545258L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.systemstore.schemas.StorePartitionerConfig
class StorePartitionerConfig extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -8369875847945101544L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.systemstore.schemas.StoreProperties
class StoreProperties extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 4058695681344329845L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.systemstore.schemas.StoreReplicaStatus
class StoreReplicaStatus extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -6150276810359697155L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.systemstore.schemas.StoreValueSchema
class StoreValueSchema extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -2622307728512171089L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.systemstore.schemas.StoreValueSchemas
class StoreValueSchemas extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -3258276091728819974L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.systemstore.schemas.StoreVersion
class StoreVersion extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 6310049090904030280L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.systemstore.schemas.StoreViewConfig
class StoreViewConfig extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- 8990245963340696629L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
Class com.linkedin.venice.systemstore.schemas.SystemStoreProperties
class SystemStoreProperties extends org.apache.avro.specific.SpecificRecordBase implements Externalizable- serialVersionUID:
- -6929265395822865701L
-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
-
Package com.linkedin.venice.utils
-
Class com.linkedin.venice.utils.BoundedHashMap
- serialVersionUID:
- 1L
-
Serialized Fields
-
maxSize
int maxSize
-
-
Class com.linkedin.venice.utils.ByteArray
class ByteArray extends Object implements Serializable- serialVersionUID:
- 1L
-
Serialized Fields
-
underlying
byte[] underlying
-
-
Class com.linkedin.venice.utils.Pair
class Pair extends Object implements Serializable- serialVersionUID:
- 1L
-
Class com.linkedin.venice.utils.SparseConcurrentList
- serialVersionUID:
- 1L
-
Class com.linkedin.venice.utils.SparseConcurrentListWithOffset
- serialVersionUID:
- 2L
-
Serialized Fields
-
offset
int offset
-
-
Class com.linkedin.venice.utils.VeniceProperties
class VeniceProperties extends Object implements Serializable- serialVersionUID:
- 1L
-
-
Package com.linkedin.venice.utils.collections
-
Package com.linkedin.venice.utils.concurrent
-
Class com.linkedin.venice.utils.concurrent.VeniceConcurrentHashMap
- serialVersionUID:
- 1L
-
Class com.linkedin.venice.utils.concurrent.VeniceReentrantReadWriteLock
class VeniceReentrantReadWriteLock extends ReentrantReadWriteLock implements Serializable- serialVersionUID:
- 1L
-
-
Package com.linkedin.venice.writer
-
Class com.linkedin.venice.writer.VeniceWriter.DefaultLeaderMetadata
class DefaultLeaderMetadata extends LeaderMetadata implements Externalizable-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
-
-
Package io.netty.channel
-
Exception io.netty.channel.ChannelException
class ChannelException extends RuntimeException implements Serializable- serialVersionUID:
- 2908618315971075004L
-
Exception io.netty.channel.ChannelPipelineException
class ChannelPipelineException extends io.netty.channel.ChannelException implements Serializable- serialVersionUID:
- 3379174210419885980L
-
Exception io.netty.channel.ConnectTimeoutException
class ConnectTimeoutException extends ConnectException implements Serializable- serialVersionUID:
- 2317065249988317463L
-
Class io.netty.channel.DefaultChannelId
class DefaultChannelId extends Object implements Serializable- serialVersionUID:
- 3884076183504074063L
-
Serialized Fields
-
data
byte[] data
-
hashCode
int hashCode
-
-
Exception io.netty.channel.EventLoopException
class EventLoopException extends io.netty.channel.ChannelException implements Serializable- serialVersionUID:
- -8969100344583703616L
-
-
Package io.netty.handler.codec.http2
-
Exception io.netty.handler.codec.http2.Http2Exception
class Http2Exception extends Exception implements Serializable- serialVersionUID:
- -6941186345430164209L
-
Serialized Fields
-
error
io.netty.handler.codec.http2.Http2Error error
-
shutdownHint
io.netty.handler.codec.http2.Http2Exception.ShutdownHint shutdownHint
-
-
Exception io.netty.handler.codec.http2.Http2Exception.ClosedStreamCreationException
class ClosedStreamCreationException extends io.netty.handler.codec.http2.Http2Exception implements Serializable- serialVersionUID:
- -6746542974372246206L
-
Exception io.netty.handler.codec.http2.Http2Exception.CompositeStreamException
class CompositeStreamException extends io.netty.handler.codec.http2.Http2Exception implements Serializable- serialVersionUID:
- 7091134858213711015L
-
Serialized Fields
-
exceptions
List<io.netty.handler.codec.http2.Http2Exception.StreamException> exceptions
-
-
Exception io.netty.handler.codec.http2.Http2Exception.HeaderListSizeException
class HeaderListSizeException extends io.netty.handler.codec.http2.Http2Exception.StreamException implements Serializable- serialVersionUID:
- -8807603212183882637L
-
Serialized Fields
-
decode
boolean decode
-
-
Exception io.netty.handler.codec.http2.Http2Exception.StreamException
class StreamException extends io.netty.handler.codec.http2.Http2Exception implements Serializable- serialVersionUID:
- 602472544416984384L
-
Serialized Fields
-
streamId
int streamId
-
-
Exception io.netty.handler.codec.http2.Http2FrameStreamException
class Http2FrameStreamException extends Exception implements Serializable- serialVersionUID:
- -4407186173493887044L
-
Serialized Fields
-
error
io.netty.handler.codec.http2.Http2Error error
-
stream
io.netty.handler.codec.http2.Http2FrameStream stream
-
-
Exception io.netty.handler.codec.http2.Http2NoMoreStreamIdsException
class Http2NoMoreStreamIdsException extends io.netty.handler.codec.http2.Http2Exception implements Serializable- serialVersionUID:
- -7756236161274851110L
-
Exception io.netty.handler.codec.http2.StreamBufferingEncoder.Http2ChannelClosedException
class Http2ChannelClosedException extends io.netty.handler.codec.http2.Http2Exception implements Serializable- serialVersionUID:
- 4768543442094476971L
-
Exception io.netty.handler.codec.http2.StreamBufferingEncoder.Http2GoAwayException
class Http2GoAwayException extends io.netty.handler.codec.http2.Http2Exception implements Serializable- serialVersionUID:
- 1326785622777291198L
-
Serialized Fields
-
debugData
byte[] debugData
-
errorCode
long errorCode
-
lastStreamId
int lastStreamId
-
-
-
Package io.netty.handler.timeout
-
Exception io.netty.handler.timeout.ReadTimeoutException
class ReadTimeoutException extends io.netty.handler.timeout.TimeoutException implements Serializable- serialVersionUID:
- 169287984113283421L
-
Exception io.netty.handler.timeout.TimeoutException
class TimeoutException extends io.netty.channel.ChannelException implements Serializable- serialVersionUID:
- 4673641882869672533L
-
Exception io.netty.handler.timeout.WriteTimeoutException
class WriteTimeoutException extends io.netty.handler.timeout.TimeoutException implements Serializable- serialVersionUID:
- -144786655770296065L
-
-
Package org.apache.avro.specific
-
Exception org.apache.avro.specific.SpecificExceptionBase
class SpecificExceptionBase extends org.apache.avro.AvroRemoteException implements Externalizable-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
-
Class org.apache.avro.specific.SpecificFixed
class SpecificFixed extends Object implements Externalizable-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
-
Class org.apache.avro.specific.SpecificRecordBase
class SpecificRecordBase extends Object implements Externalizable-
Serialization Methods
-
readExternal
- Throws:
IOException
-
writeExternal
- Throws:
IOException
-
-
-